- abort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Abort a transaction.
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- abortCheckpointOnBarrier(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- abortCheckpointOnBarrier(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- abortCheckpointOnBarrier(long, CheckpointException, OperatorChain<?, ?>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
- AbstractBroadcastStateTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
Base class for Broadcast State transformations.
- AbstractBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- AbstractBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- AbstractCollectResultBuffer<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A buffer which encapsulates the logic of dealing with the response from the
CollectSinkFunction
.
- AbstractCollectResultBuffer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
- AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
-
Deprecated.
- AbstractInput<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- AbstractInput(AbstractStreamOperatorV2<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractInput
-
- AbstractMultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
-
- AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- AbstractPerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
-
- AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operators.
- AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- AbstractStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operator factories.
- AbstractStreamOperatorFactory() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- AbstractStreamOperatorV2<OUT> - Class in org.apache.flink.streaming.api.operators
-
- AbstractStreamOperatorV2(StreamOperatorParameters<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- AbstractStreamTaskNetworkInput<T,R extends org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer<org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement>>> - Class in org.apache.flink.streaming.runtime.io
-
Base class for network-based StreamTaskInput where each channel has a designated RecordDeserializer
for spanning records.
- AbstractStreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, StatusWatermarkValve, int, Map<InputChannelInfo, R>, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- AbstractTwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- AbstractTwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- AbstractTwoInputTransformationTranslator<IN1,IN2,OUT,OP extends org.apache.flink.api.dag.Transformation<OUT>> - Class in org.apache.flink.streaming.runtime.translators
-
A base class with functionality used during translating transformations
with two inputs.
- AbstractTwoInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
-
- AbstractUdfStreamOperator<OUT,F extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.streaming.api.operators
-
This is used as the base class for operators that have a user-defined function.
- AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- accumulateFinalResults() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- acknowledgeIDs(long, Set<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
This method must be implemented to acknowledge the given set of IDs back to the message
queue.
- acknowledgeIDs(long, Set<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- acknowledgeSessionIDs(List<SessionId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- ACTIVE - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
- add(T) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
- add(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- addAll(List<T>) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
- addCoOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addEdge(Integer, Integer, int, IntermediateDataSetID) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addFeedbackEdge(Transformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Adds a feedback edge.
- addFeedbackEdge(Transformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Adds a feedback edge.
- addGlobalCommitter(DataStream<CommittableMessage<CommT>>, SerializableSupplier<Committer<CommT>>, SerializableSupplier<SimpleVersionedSerializer<CommT>>) - Static method in class org.apache.flink.streaming.api.connector.sink2.StandardSinkTopologies
-
Adds a global committer to the pipeline that runs as final operator with a parallelism of
one.
- addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Adds an ID to be stored with the current checkpoint.
- addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addInput(Transformation<?>, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
-
- addInput(Transformation<?>) - Method in class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
-
- addInputRequirement(int, StreamConfig.InputRequirement) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addLegacySource(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addMessage(CommittableMessage<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- addMultipleInputOperator(Integer, String, String, StreamOperatorFactory<OUT>, List<TypeInformation<?>>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addNode(Integer, String, String, Class<? extends TaskInvokable>, StreamOperatorFactory<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOperator(Transformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- addOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addPostCommitTopology(DataStream<CommittableMessage<CommT>>) - Method in interface org.apache.flink.streaming.api.connector.sink2.WithPostCommitTopology
-
Adds a custom post-commit topology where all committables can be processed.
- addPreCommitTopology(DataStream<CommittableMessage<CommT>>) - Method in interface org.apache.flink.streaming.api.connector.sink2.WithPreCommitTopology
-
Intercepts and modifies the committables sent on checkpoint or at end of input.
- addPreWriteTopology(DataStream<InputT>) - Method in interface org.apache.flink.streaming.api.connector.sink2.WithPreWriteTopology
-
Adds an arbitrary topology before the writer.
- addProcessedBytes(int) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given sink to this DataStream.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- addSink(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a Data Source to the streaming topology.
- addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(Integer, String, String, SourceOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>, StreamExchangeMode) - 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.
- addVirtualSideOutputNode(Integer, Integer, OutputTag) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with
the selected side-output OutputTag
.
- addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Adds a new Window
to the set of in-flight windows.
- adjustModifiedElement(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- advance(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
-
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- advanceWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Advances the Watermark of all managed
timer services
,
potentially firing event time timers.
- advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
-
- advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
-
- afterInvoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given AggregateFunction
to each window.
- aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given AggregateFunction
to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
-
- AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
-
- AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
- AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
-
- AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
-
Aggregation types that can be used on a windowed stream or keyed stream.
- aligned(String, CheckpointableTask, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- ALIGNED_CHECKPOINT_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- alignedBarrierTimeout(long) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- alignedBarrierTimeout(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- ALIGNMENT_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- ALL - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The InputSelection
instance which indicates to select all inputs.
- allActionsCompleted() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
This method must be called to end the stream task when all actions for the tasks have
been performed.
- allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
This method must be called to end the stream task when all actions for the tasks have been
performed.
- allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
-
- allChannelsRecovered() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- allChannelsRecovered() - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
-
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
The allowed lateness for elements.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- 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.
- alternating(String, CheckpointableTask, SubtaskCheckpointCoordinator, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- anyOf(int, CompletableFuture<?>) - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
-
Combine availabilityFuture
using anyOf logic with other previously registered
futures.
- apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed for windowed
groups.
- apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed for windowed
groups.
- apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
- apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
-
- apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- applyBatchExecutionSettings(int, TransformationTranslator.Context, StreamConfig.InputRequirement...) - Static method in class org.apache.flink.streaming.runtime.translators.BatchExecutionUtils
-
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- applyToKeyedState(StateDescriptor<S, VS>, KeyedStateFunction<KS, S>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
-
Applies the provided function
to the state associated with the provided state descriptor
.
- APPROXIMATE_LOCAL_RECOVERY - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- areAllDataInputsFinished() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- areAllInputsFinished() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- areAllInputsSelected() - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Tests if all inputs are selected.
- areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a
RemoteEnvironment.
- 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.
- arrayGenerator(DataGenerator<T>, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
Deprecated.
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
Handler that fails the program when timestamp monotony is violated.
- AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
Handler that does nothing when timestamp monotony is violated.
- AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
Handler that only logs violations of timestamp monotony, on WARN log level.
- AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
- asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a LatencyMarker.
- asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as queryable ValueState instance.
- asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ValueState instance.
- asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ReducingState instance.
- asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a StreamRecord.
- AssignerWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
Deprecated.
- AssignerWithPeriodicWatermarksAdapter<T> - Class in org.apache.flink.streaming.runtime.operators.util
-
- AssignerWithPeriodicWatermarksAdapter(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
-
- AssignerWithPeriodicWatermarksAdapter.Strategy<T> - Class in org.apache.flink.streaming.runtime.operators.util
-
- AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
Deprecated.
- AssignerWithPunctuatedWatermarksAdapter<T> - Class in org.apache.flink.streaming.runtime.operators.util
-
- AssignerWithPunctuatedWatermarksAdapter(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
-
- AssignerWithPunctuatedWatermarksAdapter.Strategy<T> - Class in org.apache.flink.streaming.runtime.operators.util
-
- assignTimestampsAndWatermarks(WatermarkStrategy<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and generates watermarks to signal
event time progress.
- assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a Collection
of windows that should be assigned to the element.
- asSpecializedSink() - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter
-
- asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a Watermark.
- asWatermarkStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a WatermarkStatus.
- AsyncDataOutputToOutput(Output<StreamRecord<T>>, InternalSourceReaderMetricGroup, WatermarkGauge) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
-
- AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
-
- AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
- AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
-
Output mode for asynchronous operations.
- AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
A function to trigger Async I/O operation.
- asyncInvoke(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
Trigger async operation for each stream input.
- asyncInvoke(IN, ResultFuture<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- AsyncRetryPredicate<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
Interface encapsulates an asynchronous retry predicate.
- AsyncRetryStrategies - Class in org.apache.flink.streaming.util.retryable
-
- AsyncRetryStrategies() - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies
-
- AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy<OUT> - Class in org.apache.flink.streaming.util.retryable
-
ExponentialBackoffDelayRetryStrategy.
- AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder<OUT> - Class in org.apache.flink.streaming.util.retryable
-
ExponentialBackoffDelayRetryStrategyBuilder for building a
ExponentialBackoffDelayRetryStrategy.
- AsyncRetryStrategies.FixedDelayRetryStrategy<OUT> - Class in org.apache.flink.streaming.util.retryable
-
FixedDelayRetryStrategy.
- AsyncRetryStrategies.FixedDelayRetryStrategyBuilder<OUT> - Class in org.apache.flink.streaming.util.retryable
-
FixedDelayRetryStrategyBuilder for building a FixedDelayRetryStrategy.
- AsyncRetryStrategy<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
Interface encapsulates an asynchronous retry strategy.
- AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
- AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>, ProcessingTimeService, MailboxExecutor) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- AsyncWaitOperatorFactory<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
- AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
-
- AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
-
- cache() - Method in class org.apache.flink.streaming.api.datastream.SideOutputDataStream
-
Caches the intermediate result of the transformation.
- cache() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Cache the intermediate result of the transformation.
- CACHE_CONSUMER_OPERATOR_NAME - Static variable in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
-
- CACHE_PRODUCER_OPERATOR_NAME - Static variable in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
-
- CachedDataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
- CachedDataStream(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.CachedDataStream
-
Create a new
CachedDataStream
in the given execution environment that wrap the given
physical transformation to indicates that the transformation should be cached.
- cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- CacheTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
When in batch mode, the
CacheTransformation
represents the intermediate result of the
upper stream should be cached when it is computed at the first time.
- CacheTransformation(Transformation<T>, String) - Constructor for class org.apache.flink.streaming.api.transformations.CacheTransformation
-
Creates a new Transformation
with the given name, output type and parallelism.
- CacheTransformationTranslator<OUT,T extends CacheTransformation<OUT>> - Class in org.apache.flink.streaming.runtime.translators
-
- CacheTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
-
- CacheTransformationTranslator.IdentityStreamOperator<T> - Class in org.apache.flink.streaming.runtime.translators
-
- CacheTransformationTranslator.NoOpStreamOperator<T> - Class in org.apache.flink.streaming.runtime.translators
-
- call(Callable<R>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
- call(Callable<R>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- cancel() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Cancels the source.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- cancel() - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.Cancellable
-
- cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancel() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Cancel all resources.
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- canEmitBatchOfRecords - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Returns true if this trigger supports merging of trigger state and can therefore be used with
a
MergingWindowAssigner
.
- canRetry(int) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
-
- canRetry(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
-
- canRetry(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
-
- ChainedSource(WatermarkGaugeExposingOutput<StreamRecord<?>>, StreamTaskSourceInput<?>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
-
- chainedSources - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
-
Defines the chaining scheme for the operator.
- check() - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTask.CanEmitBatchOfRecordsChecker
-
- checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
-
Deprecated.
Asks this implementation if it wants to emit a watermark.
- checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Verifies that all elements in the collection are non-null, and are of the given class, or a
subclass thereof.
- CHECKPOINT_ID_OF_IGNORED_IN_FLIGHT_DATA - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- CheckpointBarrierHandler - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
- CheckpointBarrierHandler(CheckpointableTask, Clock, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- CheckpointBarrierTracker - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
- CheckpointBarrierTracker(int, CheckpointableTask, Clock, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- checkpointCfg - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Settings that control the checkpointing behavior.
- CheckpointCommittableManager<CommT> - Interface in org.apache.flink.streaming.runtime.operators.sink.committables
-
This interface adds checkpoint meta information to the committable.
- CheckpointCommitter - Class in org.apache.flink.streaming.runtime.operators
-
This class is used to save information about which sink operator instance has committed
checkpoints to a backend.
- CheckpointCommitter() - Constructor for class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
- CheckpointConfig - Class in org.apache.flink.streaming.api.environment
-
Configuration that captures all checkpointing related settings.
- CheckpointConfig(CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- CheckpointConfig() - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- CheckpointConfig.ExternalizedCheckpointCleanup - Enum in org.apache.flink.streaming.api.environment
-
Cleanup behaviour for externalized checkpoints when the job is cancelled.
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- CheckpointedCollectResultBuffer<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A buffer which encapsulates the logic of dealing with the response from the
CollectSinkFunction
.
- CheckpointedCollectResultBuffer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
-
- CheckpointedFunction - Interface in org.apache.flink.streaming.api.checkpoint
-
This is the core interface for stateful transformation functions, meaning functions that
maintain state across individual stream records.
- checkpointedInputGate - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- CheckpointedInputGate - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
- CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
Creates a new checkpoint stream aligner.
- CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor, UpstreamRecoveryTracker) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- CHECKPOINTING_INTERVAL - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- CHECKPOINTING_MODE - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- CHECKPOINTING_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- CheckpointingMode - Enum in org.apache.flink.streaming.api
-
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
This method is used with unaligned checkpoints to mark the arrival of a first CheckpointBarrier
.
- checkpointState(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder, OperatorChain<?, ?>, boolean, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
- checkpointStopped(long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- checkpointStorage - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Our checkpoint storage.
- checkSupportedInputCount(int) - Static method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Invokes the ClosureCleaner
on the given function if closure
cleaning is enabled in the ExecutionConfig
.
- clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns a "closure-cleaned" version of the given function.
- cleanFile(String) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Creates target file if it does not exist, cleans it if it exists.
- cleanUp(Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Deletes any state in the Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).
- clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Deletes any state in the Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).
- clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Remove all registered nodes etc.
- clear() - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
- clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Deletes any state in the Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- clear() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
Clears the queue.
- clearJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Clear all registered JobListener
s.
- client - Variable in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
-
- ClientAndIterator<E> - Class in org.apache.flink.streaming.api.operators.collect
-
A pair of an
Iterator
to receive results from a streaming application and a
JobClient
to interact with the program.
- ClientAndIterator(JobClient, CloseableIterator<E>) - Constructor for class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
-
- close() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Close and clean up the execution environment.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- close() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
This method is called by the system to shut down the context.
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- close() - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- close() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- close() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- close() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- close() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- close() - 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.
- close() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- close() - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
-
- close() - Method in class org.apache.flink.streaming.experimental.CollectSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- close() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
Cleans up all internally held resources.
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Closes the resource/connection to it.
- close() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Lifecycle method to close the mailbox for action submission/retrieval.
- close() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Close the mailbox.
- close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- close() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method releases all resources of the record writer output.
- close() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- close() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Close the operator.
- closeAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- closeAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- closePartFileForBucket(BucketID) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- closer - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- closeWith(DataStream<T>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Closes the iteration.
- closeWith(DataStream<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
Closes the iteration.
- CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Creates a new CoFeedbackTransformation
from the given input.
- CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
- coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
CoGroupedStreams
represents two
DataStreams
that have been co-grouped.
- CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Creates new CoGrouped data streams, which are the first step towards building a streaming
co-group.
- CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
Internal class for implementing tagged union co-group.
- CoGroupedStreams.UnionSerializer<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupedStreams.UnionSerializerSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
CoGrouped streams that have the key for one side defined.
- CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has KeySelectors
defined for both inputs.
- CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectors
defined for both inputs as
well as a
WindowAssigner
.
- collect(DataStream<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- collect(DataStream<OUT>, String) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, without attaching a timestamp.
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.api.operators.Output
-
Emits a record to the side output identified by the given OutputTag
.
- collect(T) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- collect(T, long) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collect(OUT) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- collectAsync() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets up the collection of the elements in this
DataStream
, and returns an iterator
over the collected elements that can be used to retrieve elements once the job execution has
started.
- collectAsync(DataStream.Collector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- collectBoundedStream(DataStream<E>, String) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- CollectCoordinationRequest - Class in org.apache.flink.streaming.api.operators.collect
-
A CoordinationRequest
from the client indicating that it wants a new batch of query
results.
- CollectCoordinationRequest(String, long) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
-
- CollectCoordinationRequest(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
-
- CollectCoordinationResponse - Class in org.apache.flink.streaming.api.operators.collect
-
A CoordinationResponse
from the coordinator containing the required batch or new results
and other necessary information in serialized form.
- CollectCoordinationResponse(String, long, List<byte[]>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- CollectCoordinationResponse(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- Collector() - Constructor for class org.apache.flink.streaming.api.datastream.DataStream.Collector
-
- collectRecordsFromUnboundedStream(ClientAndIterator<E>, int) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- CollectResultFetcher<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A fetcher which fetches query results from sink and provides exactly-once semantics.
- CollectResultFetcher(AbstractCollectResultBuffer<T>, CompletableFuture<OperatorID>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
-
- CollectResultIterator<T> - Class in org.apache.flink.streaming.api.operators.collect
-
An iterator which iterates through the results of a query job.
- CollectResultIterator(CompletableFuture<OperatorID>, TypeSerializer<T>, String, CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
-
- CollectResultIterator(AbstractCollectResultBuffer<T>, CompletableFuture<OperatorID>, String, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
-
- CollectSink<IN> - Class in org.apache.flink.streaming.experimental
-
A specialized data sink to be used by DataStreamUtils.collect().
- CollectSink(InetAddress, int, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.experimental.CollectSink
-
Creates a CollectSink that will send the data to the specified host.
- CollectSinkAddressEvent - Class in org.apache.flink.streaming.api.operators.collect
-
An OperatorEvent
that passes the socket server address in the sink to the coordinator.
- CollectSinkAddressEvent(InetSocketAddress) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
-
- CollectSinkFunction<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
A sink function that collects query results and sends them back to the client.
- CollectSinkFunction(TypeSerializer<IN>, long, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- CollectSinkOperator<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
A
StreamSink
that collects query results and sends them back to the client.
- CollectSinkOperator(TypeSerializer<IN>, long, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
-
- CollectSinkOperatorCoordinator - Class in org.apache.flink.streaming.api.operators.collect
-
- CollectSinkOperatorCoordinator(int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- CollectSinkOperatorCoordinator.Provider - Class in org.apache.flink.streaming.api.operators.collect
-
- CollectSinkOperatorFactory<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
- CollectSinkOperatorFactory(TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- CollectSinkOperatorFactory(TypeSerializer<IN>, String, MemorySize, Duration) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- CollectStreamSink<T> - Class in org.apache.flink.streaming.api.operators.collect
-
- CollectStreamSink(DataStream<T>, CollectSinkOperatorFactory<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
-
- collectUnboundedStream(DataStream<E>, int, String) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- collectWithClient(DataStream<OUT>, String) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, and attaches the given timestamp.
- CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a map() transformation over two connected streams.
- commit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Commit a pre-committed transaction.
- commit(Collection<Committer.CommitRequest<CommT>>) - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
-
- commit(boolean, Committer<CommT>) - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CommittableManager
-
Commits all due committables.
- commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Mark the given checkpoint as completed in the resource.
- CommitRequestImpl<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
Internal implementation to commit a specific committable and handle the response.
- CommitRequestImpl(CommT) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- CommitRequestImpl(CommT, int, CommitRequestState) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- CommitRequestState - Enum in org.apache.flink.streaming.runtime.operators.sink.committables
-
Internal state of a committable.
- CommittableCollector<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
This class is responsible to book-keep the committing progress across checkpoints and subtasks.
- CommittableCollector(int, int) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- CommittableCollectorSerializer<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
- CommittableCollectorSerializer(SimpleVersionedSerializer<CommT>, int, int) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
-
- CommittableManager<CommT> - Interface in org.apache.flink.streaming.runtime.operators.sink.committables
-
Internal wrapper to handle the committing of committables.
- CommittableMessage<CommT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
The message send from SinkWriter
to Committer
.
- CommittableMessageSerializer<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
- CommittableMessageSerializer(SimpleVersionedSerializer<CommT>) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
-
- CommittableMessageTypeInfo<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
- CommittableSummary<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
This class tracks the information about committables belonging to one checkpoint coming from one
subtask.
- CommittableSummary(int, int, Long, int, int, int) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- CommittableWithLineage<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
Provides metadata.
- CommittableWithLineage(CommT, Long, int) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
-
- CommitterOperatorFactory<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink
-
- CommitterOperatorFactory(TwoPhaseCommittingSink<?, CommT>, boolean, boolean) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
-
- commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- 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
-
- comparePriorityTo(InternalTimer<?, ?>) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- compareTo(TimestampedInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- complete(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future with a collection of result objects.
- complete() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- completeExceptionally(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future exceptionally with an exception.
- ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Combines two extractors which will be executed one after each other.
- ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
Combines two extractors which will be executed one after each other.
- config - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
The execution configuration for this environment.
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- ConfigurableStreamPartitioner - Interface in org.apache.flink.streaming.runtime.partitioner
-
Interface for
StreamPartitioner
which have to be configured with the maximum parallelism
of the stream transformation.
- configuration - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Currently, configuration is split across multiple member variables and classes such as
ExecutionConfig
or
CheckpointConfig
.
- configuration - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The configuration of this streaming task.
- configure(ReadableConfig) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets all relevant options contained in the ReadableConfig
such as e.g.
- configure(ReadableConfig) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets all relevant options contained in the ReadableConfig
such as e.g.
- configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets all relevant options contained in the ReadableConfig
such as e.g.
- configure(int) - Method in interface org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
-
Configure the
StreamPartitioner
with the maximum parallelism of the down stream
operator.
- configure(int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- configureBufferTimeout(StreamGraph, int, Transformation<T>, long) - Static method in class org.apache.flink.streaming.util.graph.StreamGraphUtils
-
Configure a stream node's buffer timeout according to the given transformation.
- connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- connect(BroadcastStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
- ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
ConnectedStreams represent two connected streams of (possibly) different data types.
- ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- ContainingTaskDetails - Interface in org.apache.flink.streaming.runtime.tasks
-
Details about the operator containing task (such as
StreamTask
).
- CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
- context - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
- Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval.
- ContinuousFileMonitoringFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
This is the single (non-parallel) monitoring task which takes a
FileInputFormat
and,
depending on the
FileProcessingMode
and the
FilePathFilter
, it is responsible
for:
Monitoring a user-provided path.
- ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
-
- ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
-
- ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>, TypeInformation<OUT>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval as measured by the clock
of the machine on which the job is running.
- convertToPriorityEvent(int, int) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- CoordinatedOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
A factory class for the
StreamOperator
s implementing
OperatorEventHandler
.
- CoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes elements of two streams and produces a single output one.
- CoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
- CoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
- CoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
-
- CoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- copy(CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- copy(CoGroupedStreams.TaggedUnion<T1, T2>, CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- copy(IntervalJoinOperator.BufferEntry<T>, IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- copy(GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(GlobalWindow, GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns a new committable collector that deep copies all internals.
- 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.ForwardForConsecutiveHashPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- copy(StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a copy of this stream record.
- copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Copies this record into the new stream record.
- CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the cosine distance between two given vectors.
- CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps up to a certain amount of elements.
- CountingOutput<OUT> - Class in org.apache.flink.streaming.api.operators
-
Wrapping
Output
that updates metrics on the number of emitted elements.
- CountingOutput(WatermarkGaugeExposingOutput<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.CountingOutput
-
- CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the count of elements in a pane reaches the given count.
- countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling count windows.
- countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding count windows.
- countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling count windows.
- countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding count windows.
- cover(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns the minimal window covers both this window and the given window.
- create(OperatorCoordinator.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
-
- create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager.Provider
-
- create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - Static method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
-
- create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - Static method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
-
- create(String, TypeSerializer<T>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- 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(TaskInvokable, CheckpointedInputGate[], StreamConfig.InputConfig[], IOManager, MemoryManager, TaskIOMetricGroup, Counter, MultipleInputStreamOperator<?>, WatermarkGauge[], StreamConfig, Configuration, Configuration, ExecutionConfig, ClassLoader, OperatorChain<?, ?>, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
-
- create(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
-
- create(TaskInvokable, CheckpointedInputGate[], IOManager, MemoryManager, TaskIOMetricGroup, TwoInputStreamOperator<IN1, IN2, ?>, WatermarkGauge, WatermarkGauge, OperatorChain<?, ?>, StreamConfig, Configuration, Configuration, ExecutionConfig, ClassLoader, Counter, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
-
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
-
The factory method; creates the value.
- createAndRestore(List<? extends Collection<S>>) - Method in class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
-
Creates a new state backend and restores it from the provided set of state snapshot
alternatives.
- createBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
- createBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- createBrokerIdString(JobID, String, int) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
Creates the identification string with which head and tail task find the shared blocking
queue for the back channel.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
-
Deprecated.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- createCheckpointBarrierHandler(CheckpointableTask, StreamConfig, SubtaskCheckpointCoordinator, String, List<IndexedInputGate>[], List<StreamTaskSourceInput<?>>, MailboxExecutor, TimerService) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
-
- createCheckpointedMultipleInputGate(MailboxExecutor, List<IndexedInputGate>[], TaskIOMetricGroup, CheckpointBarrierHandler, StreamConfig) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
-
- createExceptionTypePredicate(Class<? extends Throwable>) - Static method in class org.apache.flink.streaming.util.retryable.RetryPredicates
-
Creates a predicate on given exception type.
- createExecutionEnvironment(Configuration) - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
-
Creates a StreamExecutionEnvironment from this factory.
- createExecutor(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorFactory
-
Creates a new executor for the given priority.
- createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with InputFormat
.
- createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with InputFormat
.
- createInputGate(List<IndexedInputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
- createInputProcessor(List<IndexedInputGate>[], StreamConfig.InputConfig[], WatermarkGauge[], Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- createInstance() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- createIterationSourceAndSink(int, int, int, long, int, int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- createJobGraph(StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- createJobGraph(ClassLoader, StreamGraph, JobID) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
-
- 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
-
- createLocalEnvironment(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
-
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
-
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction
and watermark generation.
- createMasterTriggerRestoreHook() - Method in interface org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
-
Creates the hook that should be called by the checkpoint coordinator.
- createNoOpEventTimeLogic(WatermarkStrategy<E>, MetricGroup) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
- createOperator(StreamOperatorFactory<OUT>, StreamTask<OUT, ?>, StreamConfig, Output<StreamRecord<OUT>>, OperatorEventDispatcher) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
-
Creates a new operator using a factory and makes sure that all special factory traits are
properly handled.
- createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
-
- createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
-
- createProcessingTimeService(MailboxExecutor) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceFactory
-
Creates a new processing time service with the mailbox executor.
- createProgressiveEventTimeLogic(WatermarkStrategy<E>, MetricGroup, ProcessingTimeService, long) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
- createRecordWriterDelegate(StreamConfig, Environment) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createRecursiveProductFieldAccessor(int, TypeInformation<T>, FieldAccessor<R, F>, ExecutionConfig) - Method in interface org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
-
- createRegisterTimerCallback(MailboxExecutor, TimerService) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
-
- createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createResource() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Creates/opens/connects to the resource that is used to store information.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- createSimpleProductFieldAccessor(int, TypeInformation<T>, ExecutionConfig) - Method in interface org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
-
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<Object>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
-
The implementation should return an instance of OperatorEventHandler
.
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Create the operator.
- createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - Method in class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
-
- createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
-
- createStreamTaskStateInitializer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
-
- createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
-
- createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator, String, CheckpointableTask, Clock, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
-
- createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
-
- createWithSeparateOutputs(PushingAsyncDataInput.DataOutput<E>, WatermarkOutput, WatermarkOutput, TimestampAssigner<E>, WatermarkGenerator<E>) - Static method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and
watermarks to the different WatermarkOutputs.
- createWriter(Sink.InitContext) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSink
-
- createWriter(Sink.InitContext) - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- currentTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- currentWatermark() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- currentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- CustomPartitionerWrapper<K,T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that selects the channel with a user defined partitioner function on a key.
- CustomPartitionerWrapper(Partitioner<K>, KeySelector<T, K>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- CustomSinkOperatorUidHashes - Class in org.apache.flink.streaming.api.datastream
-
This class is responsible to hold operator Uid hashes from the common operators of the sink.
- CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder - Class in org.apache.flink.streaming.api.datastream
-
- emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- emitCompletedElement(TimestampedCollector<OUT>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Emits one completed element from the head of this queue into the given output.
- emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Output
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
-
- emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
-
- emitNext(PushingAsyncDataInput.DataOutput<IN>) - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- emitNext(PushingAsyncDataInput.DataOutput<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
-
Pushes elements to the output from current data input, and returns the input status to
indicate whether there are more available data in current input.
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
-
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
-
- emitPeriodicWatermark() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- emitRecord(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
-
- emitRecord(StreamRecord<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
-
- emitRecord(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
-
- emitsProgressiveWatermarks() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Output
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
-
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.Output
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
-
- EMPTY_RESULT_PREDICATE - Static variable in class org.apache.flink.streaming.util.retryable.RetryPredicates
-
A predicate matches empty result which means an empty
Collection
.
- ENABLE_CHECKPOINTS_AFTER_TASKS_FINISH - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- ENABLE_UNALIGNED - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- enableApproximateLocalRecovery(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables the approximate local recovery mode.
- enableChangelogStateBackend(boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enable the change log for current state backend.
- enableCheckpointing(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enables checkpointing for the streaming job.
- enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enables checkpointing for the streaming job.
- enableCheckpointing(long, CheckpointingMode, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- enableCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- enableExternalizedCheckpoints(CheckpointConfig.ExternalizedCheckpointCleanup) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- enableTransactionTimeoutWarnings(double) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Enables logging of warnings if a transaction's elapsed time reaches a specified ratio of the
transactionTimeout
.
- enableUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
- enableUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
- endData(StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- endInput() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- endInput(int) - Method in interface org.apache.flink.streaming.api.operators.BoundedMultiInput
-
It is notified that no more data will arrive from the input identified by the inputId
.
- endInput() - Method in interface org.apache.flink.streaming.api.operators.BoundedOneInput
-
It is notified that no more data will arrive from the input.
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
-
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
-
- endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Ends the main operator input specified by inputId
).
- endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- endOperatorInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Ends an input of the operator contained by this wrapper.
- environment - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- environment - Variable in class org.apache.flink.streaming.api.datastream.DataStream
-
- environment - Variable in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
-
- equals(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
-
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
-
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
- equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- equals(Object) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
-
Specifies a KeySelector
for elements from the second input.
- equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
-
Specifies a KeySelector
for elements from the second input with explicit type
information for the key type.
- equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
-
Specifies a KeySelector
for elements from the second input.
- equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
-
Specifies a KeySelector
for elements from the second input with explicit type
information for the key type.
- eraseTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- eraseTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- EuclideanDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the euclidean distance between two given points.
- EuclideanDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- EuclideanDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- EventTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the timestamp of the
elements.
- EventTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- EventTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the watermark passes the end of the window to which a pane
belongs.
- evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
- evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
-
Optionally evicts elements.
- evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
- evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
-
Optionally evicts elements.
- evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- EvictingWindowOperator<K,IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- EvictingWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the Evictor
that should be used to evict elements from a window before emission.
- evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the Evictor
that should be used to evict elements from a window before
emission.
- evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the Evictor
that should be used to evict elements from a window before
emission.
- evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the Evictor
that should be used to evict elements from a window before emission.
- Evictor<T,W extends Window> - Interface in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
can remove elements from a pane before/after the evaluation of WindowFunction
and after the window evaluation gets triggered by a
Trigger
- evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- Evictor.EvictorContext - Interface in org.apache.flink.streaming.api.windowing.evictors
-
A context object that is given to
Evictor
methods.
- ExceptionInChainedOperatorException - Exception in org.apache.flink.streaming.runtime.tasks
-
A special exception that signifies that the cause exception came from a chained operator.
- ExceptionInChainedOperatorException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
-
- ExceptionInChainedOperatorException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
-
- exceptionPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryPredicate
-
An Optional Java that defines a condition on asyncFunction's exception which
will trigger a later reattempt operation, will be called before user's
ResultFuture#completeExceptionally.
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
-
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- execute() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- execute(ThrowingRunnable<? extends Exception>, String, Object...) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
-
- executeAndCollect() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
- executeAndCollect(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
- executeAndCollect(int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
- executeAndCollect(String, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
- executeAsync() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program asynchronously.
- executeAsync(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution asynchronously.
- executeAsync(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution asynchronously.
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- ExecutionCheckpointingOptions - Class in org.apache.flink.streaming.api.environment
-
Execution ConfigOption
for configuring checkpointing related parameters.
- ExecutionCheckpointingOptions() - Constructor for class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- ExponentialBackoffDelayRetryStrategy(int, long, long, double, Predicate<Collection<OUT>>, Predicate<Throwable>) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
-
- ExponentialBackoffDelayRetryStrategyBuilder(int, long, long, double) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
-
- EXTERNALIZED_CHECKPOINT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- ExternallyInducedSource<T,CD> - Interface in org.apache.flink.streaming.api.checkpoint
-
Sources that implement this interface delay checkpoints when receiving a trigger message from the
checkpoint coordinator to the point when their input data/events indicate that a checkpoint
should be triggered.
- ExternallyInducedSource.CheckpointTrigger - Interface in org.apache.flink.streaming.api.checkpoint
-
Through the CheckpointTrigger
, the source function notifies the Flink source operator
when to trigger the checkpoint.
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
- extract(FROM) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
- extract(FROM) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.extractor.Extractor
-
Extracts/Converts the given input to an object of the output type.
- extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
- extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
- extract(T) - Method in interface org.apache.flink.streaming.api.windowing.assigners.SessionWindowTimeGapExtractor
-
Extracts the session time gap.
- extractAscendingTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
Extracts the timestamp from the given element.
- extractFieldTypes(int[], TypeInformation<?>) - Static method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- ExtractionAwareDeltaFunction<DATA,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
Extend this abstract class to implement a delta function which is aware of extracting the data on
which the delta is calculated from a more complex data structure.
- ExtractionAwareDeltaFunction(Extractor<DATA, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
- Extractor<FROM,TO> - Interface in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extractors allow to extract/convert one type to another.
- extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
Deprecated.
- extractTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.TimestampAssigner
-
Deprecated.
Assigns a timestamp to an element, in milliseconds since the Epoch.
- extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- extractTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
Extracts the timestamp from the given element.
- extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
-
Deprecated.
- fairSelectNextIndex(long, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the available inputs for reading.
- fairSelectNextIndex(long, long, int) - Static method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the available inputs for reading.
- fairSelectNextIndexOutOf2(int, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the two inputs for reading.
- fairSelectNextIndexOutOf2(int, int, int) - Static method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the two inputs for reading.
- FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- FeedbackTransformation(Transformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Creates a new FeedbackTransformation
from the given input.
- FieldAccessor<T,F> - Class in org.apache.flink.streaming.util.typeutils
-
These classes encapsulate the logic of accessing a field specified by the user as either an index
or a field expression string.
- FieldAccessor() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- FieldAccessorFactory - Class in org.apache.flink.streaming.util.typeutils
-
- FieldAccessorFactory() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
- FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of an array.
- FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the first field (id 0) from the array.
- FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the field with the given id from the array.
- FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of a tuple.
- FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the field with the given id from the tuple.
- FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts multiple fields from an array and puts them into a new array of the specified type.
- FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
Extracts multiple fields from an array and puts them in the given order into a new array of
the specified type.
- FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
- FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
Extracts one or more fields of the type Double from a tuple and puts them into a new double[]
(in the specified order).
- fieldType - Variable in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- FileLifeCycleListener<BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
-
Listener about the status of file.
- 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
-
Deprecated.
- FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
-
Deprecated.
The watch type of the FileMonitoringFunction
.
- FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The finalize method shuts down the timer.
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- finish() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
This method is called at the end of data processing.
- finish() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- finish() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- finish() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- finish() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called at the end of data processing.
- finish() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
- finish(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Finishes the wrapped operator and propagates the finish operation to the next wrapper that
the
StreamOperatorWrapper.next
points to.
- FinishedDataOutput<IN> - Class in org.apache.flink.streaming.runtime.io
-
- FinishedDataOutput() - Constructor for class org.apache.flink.streaming.runtime.io.FinishedDataOutput
-
- FinishedOnRestoreInput<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
A fake
Input
for finished on restore tasks.
- FinishedOnRestoreInput(RecordWriterOutput<?>[], int) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- finishedOnRestoreInput - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- FinishedOnRestoreMainOperatorOutput<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A fake main operator output that skips all the following operators for finished on restored
tasks.
- FinishedOnRestoreMainOperatorOutput(RecordWriterOutput<?>[]) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
The
OperatorChain
that is used for restoring tasks that are
TaskStateManager.isTaskDeployedAsFinished()
.
- FinishedOperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Closes all operators in a chain effect way.
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- finishProcessing(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
This method is called at the end of data processing.
- finishRecoveringContext(Collection<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Callback for subclasses which is called after restoring (each) user context.
- finishRecovery() - Method in interface org.apache.flink.streaming.runtime.io.RecoverableStreamTaskInput
-
- finishRecovery() - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
-
- FIRST - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The InputSelection
instance which indicates to select the first input.
- firstOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- FixedDelayRetryStrategyBuilder(int, long) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
-
- flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreams
and maps the output to a
common type.
- flatMap(CoFlatMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreams
and maps the output to a
common type.
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- flatMap(FlatMapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the first of the connected streams.
- flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the second of the connected streams.
- flattenedChannelIndices - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- floatGenerator(float, float) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- floatGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method should be called before finishing the record emission, to make sure any data that
is still buffered will be sent.
- forBulkFormat(Path, BulkWriter.Factory<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- FORCE_CHECKPOINTING - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- FORCE_UNALIGNED - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism and maximum parallelism of this operator to one.
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Performs an action for each registered timer.
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Performs an action for each registered timer.
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- forInputGate(InputGate) - Static method in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
-
- format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- forRowFormat(Path, Encoder<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- forSink(DataStream<T>, Sink<T>, CustomSinkOperatorUidHashes) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
- forSinkV1(DataStream<T>, Sink<T, ?, ?, ?>, CustomSinkOperatorUidHashes) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
- forTimestamp(long) - Static method in class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
-
Creates a
SinkFunction.Context
that throws an exception when trying to access the
current watermark or processing time.
- forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements are forwarded to
the local subtask of the next operation.
- ForwardForConsecutiveHashPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
If there are multiple consecutive and the same hash shuffles, SQL planner will change them except
the first one to use forward partitioner, so that these operators can be chained to reduce
unnecessary shuffles.
- ForwardForConsecutiveHashPartitioner(StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
Create a new ForwardForConsecutiveHashPartitioner.
- ForwardForUnspecifiedPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
- ForwardForUnspecifiedPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
-
- ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that forwards elements only to the locally running downstream operation.
- ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- from(InputSelection) - Static method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
-
Returns a Builder
that uses the input mask of the specified selection
as
the initial mask.
- from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- fromCollection(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Iterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromCollection(Iterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromElements(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromElements(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data 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
-
- FromElementsFunction(T...) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromElementsFunction(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.
- fromSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains a sequence of numbers (longs) and is useful for
testing and for cases that just need a stream of N events of any kind.
- fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a data
Source
to the environment to get a
DataStream
.
- fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a data
Source
to the environment to get a
DataStream
.
- FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
A
SourceFunction
that reads elements from an
SplittableIterator
and emits them.
- FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- GaugePeriodTimer - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
- GaugePeriodTimer(TimerGauge) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
-
- generate() - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- generateOperatorDescription(Function, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- generateOperatorName() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- generateStreamGraph(List<Transformation<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generates a
StreamGraph
that consists of the given
transformations
and is configured with the configuration of this environment.
- GenericWriteAheadSink<IN> - Class in org.apache.flink.streaming.runtime.operators
-
Generic Sink that emits its input elements into an arbitrary backend.
- GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- get() - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
- get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Looks up the value mapped under the given key.
- get(T) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the value of the field (specified in the constructor) of the given record.
- getAccessor(TypeInformation<T>, int, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the given field position, which can be used to get and
set the specified field on instances of this type.
- getAccessor(TypeInformation<T>, String, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the field that is given by a field expression, which can
be used to get and set the specified field on instances of this type.
- getActiveSerializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- getActiveSerializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
-
- getActiveTimerTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getAddress() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- getAlignmentTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- getAllFutures() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getAllOperatorFactory() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Returns an
Iterable
which traverses all operators in forward topological order.
- getAllOperators(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Returns an
Iterable
which traverses all operators in forward or reverse topological
order.
- getAllowedLateness() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- getArity() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- getAsyncCheckpointStartDelayNanos() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
-
- getBackoffTimeMillis(int) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
-
- getBackoffTimeMillis(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
-
- getBackoffTimeMillis(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
-
- getBindAddress() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- getBoundedness() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- getBoundedness() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
- getBoundedness() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getBoundedness() - Method in interface org.apache.flink.streaming.api.transformations.WithBoundedness
-
Returns the Boundedness
of this Transformation
.
- getBroadcastInput() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
-
Fetches the BroadcastState
with the specified name.
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
Fetches a read-only view of the broadcast state with the specified name.
- getBroadcastStateDescriptors() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getBroadcastStateDescriptors() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- getBucketId() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
-
- getBucketPath() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum time frequency (milliseconds) for the flushing of the output buffers.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getCachedFiles() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Get the list of cached files that were registered for distribution among the task managers.
- getCancelables() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainedSource(StreamConfig.SourceInputConfig) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChainedSourceOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChainIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
-
Deprecated.
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Get the chaining strategy of operator factory.
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
- getChannel(int) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- getChannelInfos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- getChannelInfos() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getChannelStateWriter() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- getCheckpointCommittablesUpTo(long) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- 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
-
- getCheckpointId() - Method in interface org.apache.flink.streaming.api.connector.sink2.CommittableMessage
-
Returns the checkpoint id or empty if the message does not belong to a checkpoint.
- getCheckpointId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getCheckpointId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
-
- getCheckpointId() - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
-
Returns the checkpoint id in which the committable was created.
- getCheckpointIdOfIgnoredInFlightData() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the checkpointing mode (exactly-once vs.
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing mode (exactly-once vs.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing interval or -1 if checkpointing is disabled.
- getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Returns the checkpoint lock.
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the checkpointing mode.
- getCheckpointStartDelayNanos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- getCheckpointStorage() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- getCheckpointStorage(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getCheckpointStorage() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getCheckpointStorage() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCheckpointStorage() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
- getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum time that a checkpoint may take before being discarded.
- getClientConfiguration() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- getClock() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- getCoLocationGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getCommittable() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
-
- getCommittable() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- getCommitterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
-
- getCompatibleVersions() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- getCompletionFuture() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- getCompletionFuture() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config object.
- getConfiguration() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gives read-only access to the underlying configuration of this environment.
- getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getConsumeClusterDatasetId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getConsumerMaxParallelism() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getConsumerParallelism() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- getContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getCoordinatorListeningID() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- getCoordinatorProvider(String, OperatorID) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
-
Get the operator coordinator provider for this operator.
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
Get the key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
-
Get key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
Get key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getCurrentTableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the current table capacity, i.e., the number of slots in the hash table, without and
overflow chaining.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
-
Deprecated.
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
Deprecated.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getDataSetId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getDatasetId() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- getDefaultBufferTimeout() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the default buffer timeout to be used.
- getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getDefaultSavepointDirectory() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the default savepoint directory for this Job.
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns the default trigger associated with this WindowAssigner
.
- getDelta(DATA, DATA) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
-
Calculates the delta between two given data points.
- getDelta(DATA, DATA) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
This method takes the two data point and runs the set extractor on it.
- getDescription() - Method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
Defines the behavior of this partitioner, when downstream rescaled during recovery of
in-flight data.
- getElement() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
-
- getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the end timestamp of this window.
- getEndOfInputCommittable() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- getEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getEnvironment() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getExchangeMode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getExchangeMode() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Gets the execution config defined on the execution environment of the job to which this
operator belongs.
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Gets the execution config defined on the execution environment of the job to which this
operator belongs.
- getExecutionConfig() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is
currently executed.
- getExecutionEnvironment(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is
currently executed.
- getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates the plan with which the system will execute the program, and returns it as a String
using a JSON representation of the execution data flow graph.
- getExternalizedCheckpointCleanup() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns the cleanup behaviour for externalized checkpoints.
- getExternalResourceInfos(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the list of feedback Transformations
.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the list of feedback Transformations
.
- getFieldType() - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the TypeInformation for the type of the field.
- getFinishedOnRestoreInputOrDefault(Input) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- 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.sink.OutputFormatSinkFunction
-
Deprecated.
- getFormat() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
Returns the InputFormat
.
- getGlobalAggregateManager() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the global aggregate manager for the current job.
- getGlobalCommittableSerializer() - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
-
- getGlobalCommitter() - Method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
-
- getGlobalCommitterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
-
- getGlobalModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- getGlobalStreamExchangeMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getGraphGeneratorConfig() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Retrieves additional configuration for the graph generation process.
- getHashPartitioner() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
- 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
-
- getIndexInSubtaskGroup() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
-
- 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
-
- getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input Transformation
of this TwoInputTransformation
.
- getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the second input Transformation
of this TwoInputTransformation
.
- getInputChannelStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getInputChannelStatus(int) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
- getInputEdge() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
-
- getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInputFormat() - Method in interface org.apache.flink.streaming.api.operators.InputFormatOperatorFactory
-
- getInputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
-
- getInputGateIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
-
- getInputGateIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getInputIndex() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- getInputIndex() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- getInputIndex() - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
-
Returns the input index of this input.
- getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getInputMask() - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
- getInputRequirement() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
-
- getInputRequirements() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getInputs() - Method in interface org.apache.flink.streaming.api.operators.MultipleInputStreamOperator
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- getInputSelectable() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
-
- getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the input split provider associated with the operator.
- getInputStream() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- 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.
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
Returns the TypeInformation
for the elements of the input.
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Returns the TypeInformation
for the elements of the input.
- getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the second input.
- getInputTypes() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
Returns the TypeInformation
for the elements from the inputs.
- getIntermediateDatasetIdToProduce() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getInternalIndex() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- getInternalIndex() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a
InternalTimerService
that can be used to query current processing time and
event time and to set timers.
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns a
InternalTimerService
that can be used to query current processing time and
event time and to set timers.
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
-
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
-
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- getIterationId() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getJobConfiguration() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
-
- getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets the assembled JobGraph
with a random JobID
.
- getJobGraph(ClassLoader, JobID) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets the assembled JobGraph
with a specified JobID
.
- getJobId() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config JobListeners.
- getJobManagerOwnedState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
-
- getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobStatusHooks() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobType() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- getKey() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the key that is bound to this timer.
- getKey() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- getKey() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
-
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- getKeyGroupRange() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getKeys(String, N) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getKeysAndNamespaces(String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- 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.api.transformations.KeyedBroadcastStateTransformation
-
- getKeySelector() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getKeySerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the key serializer for the queryable state instance.
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- getKeySerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getKeyType() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the type of the key by which the stream is partitioned.
- getKeyTypeInfo() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
- getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getLastCheckpointedOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- getLeftTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
- getLegacyTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
- getLength() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getMailboxExecutor() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- getMailboxExecutor(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Returns an executor service facade to submit actions to the mailbox.
- getMailboxExecutorFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getMailboxMetricsControl() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- getMailCounter() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Gets Counter
for number of mails processed.
- getMainMailboxExecutor() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- getMainOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getMainOperatorOutput() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- getMainOperatorOutput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getManagedMemoryFractionOperatorUseCaseOfSlot(ManagedMemoryUseCase, Configuration, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Fraction of total managed memory in the slot that this operator should use for the given use
case.
- getManagedMemoryOperatorScopeUseCaseWeights() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getManagedMemorySlotScopeUseCases() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getMarkedTime() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Returns the timestamp marked by the LatencyMarker.
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getMaxOutOfOrdernessInMillis() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum degree of parallelism defined for the program.
- getMaxParallelism() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- getMaxPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- getMaxSubtasksPerChannelStateFile() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- getMaxSubtasksPerChannelStateFile() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the metric group for this
Evictor
.
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the metric group for this
Trigger
.
- getMetricGroup() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the minimal pause between checkpointing attempts.
- getMinResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the minimum resources for this operator.
- getMinResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getModificationTime() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
- getMutex() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the name of the current data stream.
- getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the name of the task, in the form "taskname (2/5)".
- getNamespace() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the namespace that is bound to this timer.
- getNamespace() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- getNamespaceSerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
- getNestedSerializers(CoGroupedStreams.UnionSerializer<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
-
- getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- getNestedSerializers(IntervalJoinOperator.BufferEntrySerializer<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
-
- getNestedSerializers(TimerSerializer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
-
- getNestedSerializers(StreamElementSerializer<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
-
- getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
-
- getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
-
- getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- getNumActiveTimers() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getNumberOfCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getNumberOfFailedCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getNumberOfInputChannels() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- getNumberOfInputChannels() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getNumberOfNetworkInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfPendingCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getNumberOfRetries() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- getNumberOfSubtasks() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getNumberOfSubtasks() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns number of subtasks.
- getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements produced in total by this function.
- getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements emitted so far.
- getOffset() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- getOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
-
- getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperator() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getOperator() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getOperatorDescription() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getOperatorEventGateway(OperatorID) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
-
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
Returns the StreamOperatorFactory
of this Transformation.
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
Returns the StreamOperatorFactory
of this LegacySourceTransformation
.
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the StreamOperatorFactory
of this Transformation.
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the StreamOperatorFactory
of this Transformation.
- getOperatorID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getOperatorId() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
-
- getOperatorID() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getOperatorID() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- getOperatorId() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getOperatorIdFuture() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Return the operator name.
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Return the operator name.
- getOperatorNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getOperatorUniqueID() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returned value is guaranteed to be unique between operators within the same job and to be
stable and the same across job submissions.
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutput() - Method in class org.apache.flink.streaming.api.datastream.DataStream.Collector
-
Returns an iterator over the collected elements.
- getOutput() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- getOutputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutputFormat() - Method in interface org.apache.flink.streaming.api.operators.OutputFormatOperatorFactory
-
- getOutputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
-
- getOutputTag() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getOutputTag() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getOutputTag() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the parallelism for this operator.
- getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
-
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Retrieves a State
object that can be used to interact with fault-tolerant state
that is scoped to the window and key of the current trigger invocation.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the
StreamPartitioner
that must be used for partitioning the elements of the
input
Transformation
.
- getPartitionType() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getPassThroughInputs() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
-
- getPendingCommitTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getPendingTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getPersistentDataSetId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the port of the master (JobManager), where the program will be executed.
- getPort() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Returns the port on which the iterator is getting the data.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the preferred resources for this operator.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getPriority() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- getProcessingTimeDelay(long, long) - Static method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
-
Returns the remaining delay of the processing time specified by processingTimestamp
.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns the
ProcessingTimeService
responsible for getting the current processing time
and registering timers.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns the
ProcessingTimeService
responsible for getting the current processing time
and registering timers.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- getProcessingTimeServiceFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the name under which the state can be queried.
- getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- getRecordProcessor(Input<T>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
- getRecordProcessor1(TwoInputStreamOperator<T, ?, ?>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
- getRecordProcessor2(TwoInputStreamOperator<?, T, ?>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
- getReducer() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getRegularInput() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- 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.
- getRestoredCheckpointId() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns non-empty if the states provided by this context are restored from a
checkpoint/savepoint.
- getResults(TypeSerializer<T>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- getResultSubpartitionStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getRetryPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
-
- getRetryPredicate() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
-
- getRetryPredicate() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
-
- getRightTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getSavepointDir(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getSavepointDirectory() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSavepointRestoreSettings() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- 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
-
- getSerializationFuture() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getSerializer() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getSideOutput(OutputTag<X>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the
DataStream
that contains the elements that are emitted from an operation
into the side output with the given
OutputTag
.
- getSink() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getSink() - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
-
- getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSinkOperatorsUidHashes() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the length of this policy's time interval.
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSlotSharingGroup(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Determines the slot sharing group of an operation across virtual nodes.
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getSlotSharingGroup() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the slot sharing group for the given transformation.
- getSlotSharingGroupResource(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSortedInputs() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
-
- getSource() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, Output<StreamRecord<OUT>>, long, long, boolean) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSourceMetricGroup() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- getSourceNodeId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- getSourceOutput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
-
- getSourceReader() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- getSourceTaskInput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
-
- getSourceTaskInput(StreamConfig.SourceInputConfig) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getSourceTaskInputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getSourceVertex(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
- getStaggerOffset(long, long) - Method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
- getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the starting timestamp of the window.
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getState() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns the current state of the mailbox as defined by the lifecycle enum
TaskMailbox.State
.
- getState() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the state backend that defines how to store and checkpoint state.
- getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the state descriptor for the queryable state instance.
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this Sink.
- 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.
- getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the first input.
- getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the second input.
- getStateKeySelectors() - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
-
- getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStatePartitioners() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Returns the state window for the given in-flight Window
.
- getStatus() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- getStreamConfig() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- getStreamEdges(int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamEdgesOrThrow(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Deprecated.
- getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getStreamGraph(boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Getter of the
StreamGraph
of the streaming job with the option to clear previously
registered
transformations
.
- getStreamGraph() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the
StreamGraph
being created as the transformations of a pipeline are
translated to their runtime implementations.
- getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNodeIds(Transformation<?>) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the ids of the nodes in the
StreamGraph
corresponding to the provided
transformation.
- getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStreamOperator() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
-
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- getStreamOperatorClass(ClassLoader) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Returns the runtime class of the stream operator.
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
-
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
-
- getStreamOperatorFactory(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getStreamRecord() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getStreamTimeCharacteristic() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getSubtaskId() - Method in interface org.apache.flink.streaming.api.connector.sink2.CommittableMessage
-
The subtask that created this committable.
- getSubtaskId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
-
- getSubtaskId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
-
- getSubtaskId() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns subtask id.
- getSubtaskIndex() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getSummary() - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CommittableManager
-
Returns a summary of the current commit progress.
- getTailOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTargetVertex(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getTaskLocalState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
-
- getTaskManagerRuntimeInfo() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the task manager runtime info of the task manager running this stream task.
- getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getTimerDelay(Clock, CheckpointBarrier) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
-
- getTimerServiceProvider(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTimerServiceProvider() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
- getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the timestamp of the timer.
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
Returns the timestamp associated with this
Watermark
in milliseconds.
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the timestamp associated with this stream value in milliseconds.
- getTolerableCheckpointFailureNumber() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Get the defined number of consecutive checkpoint failures that will be tolerated, before the
whole job is failed over.
- getTotalFields() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Returns the
Transformation
that represents the operation that logically creates this
DataStream
.
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Returns the transformation that contains the actual sink operator of this sink.
- getTransformations() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getTransformationToCache() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitiveChainedTaskConfigsWithSelf(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- 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.LegacySinkTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the type of the stream.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the first input.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the first input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the second input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the second input.
- getTypeClass() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTypeSerializer() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
-
- getTypeSerializerIn(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Deprecated.
- getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Deprecated.
- getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializersIn() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the time unit for this policy's time interval.
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
Defines the behavior of this partitioner, when upstream rescaled during recovery of in-flight
data.
- getUserArtifacts() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getUserClassloader() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- getUserCodeClassLoader() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
-
- getUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
-
- getUserFunction() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
-
- getUserFunction() - Method in interface org.apache.flink.streaming.api.operators.UserFunctionProvider
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.transformations.BroadcastStateTransformation
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
-
- getUserFunctionClassName() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
-
- getUserFunctionClassName() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
-
- getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Since the streaming API does not implement any parametrization of functions via a
configuration, the config returned here is actually empty.
- getUserHash() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
-
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the value wrapped in this stream value.
- getVersion() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
-
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
-
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- getVersion() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- getVersion() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
-
- getVertexDescriptionMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getVertexIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getVertexNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the wait time.
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the wait time.
- getWatermarkGauge() - Method in class org.apache.flink.streaming.api.operators.CountingOutput
-
- getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
-
- getWatermarkGauge() - Method in interface org.apache.flink.streaming.runtime.tasks.WatermarkGaugeExposingOutput
-
- getWatermarkStrategy() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getWatermarkStrategy() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Returns the WatermarkStrategy
to use.
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a TypeSerializer
for serializing windows that are assigned by this WindowAssigner
.
- getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Method to get the window start for a timestamp.
- getWriterForVersion(int, InternalTimersSnapshot<K, N>, TypeSerializer<K>, TypeSerializer<N>) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- getWriterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
-
- 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.
- GLOBAL_COMMITTER_TRANSFORMATION_NAME - Static variable in class org.apache.flink.streaming.api.connector.sink2.StandardSinkTopologies
-
- GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that sends all elements to the downstream operator with subtask ID=0.
- GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- globalState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- GlobalStreamExchangeMode - Enum in org.apache.flink.streaming.api.graph
-
This mode decides the default ResultPartitionType
of job edges.
- GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
The default window into which all data is placed (via
GlobalWindows
).
- GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindow.Serializer.GlobalWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
-
Serializer configuration snapshot for compatibility and format evolution.
- GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
-
A trigger that never fires, as default Trigger for GlobalWindows.
- GlobalWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer.GlobalWindowSerializerSnapshot
-
- ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- IdentityStreamOperator() - Constructor for class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
-
- IDLE - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- IDLE_STATUS - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- ifException(Predicate<Throwable>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
-
- ifException(Predicate<Throwable>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
-
- ifResult(Predicate<Collection<OUT>>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
-
- ifResult(Predicate<Collection<OUT>>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
-
- ignoreFailuresAfterTransactionTimeout() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
-
Deprecated.
- IMMEDIATE - Static variable in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
- inEventTime() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
-
Sets the time characteristic to event time.
- IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
Deprecated.
- IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
Deprecated.
- init() - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- initializeOperatorState(StreamOperatorStateHandler.CheckpointedStreamOperator) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- initializeState(FunctionInitializationContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when the parallel function instance is created during distributed
execution.
- initializeState(ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
Initializes the state after recovery from a failure.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- initializeState(StreamTaskStateInitializer) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Provides a context to initialize all state in the operator.
- initializeState(StateInitializationContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- initializeUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- initInputsCheckpoint(long, CheckpointOptions) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Initialize new checkpoint.
- initReader() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
Initializes the reader.
- initSourceMetricGroup() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- inProcessingTime() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
-
Sets the time characteristic to processing time.
- Input<IN> - Interface in org.apache.flink.streaming.api.operators
-
- input1WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
- input2WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
- InputChannelStatus() - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- InputFormatOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Input format source operator factory.
- InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- InputGateUtil - Class in org.apache.flink.streaming.runtime.io
-
Utility for dealing with input gates.
- inputId - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
-
- inputIndex - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- inputProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The input processor.
- InputProcessorUtil - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
- InputProcessorUtil() - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
-
- inputs - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- InputSelectable - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators that can select the input to get
StreamRecord
.
- InputSelection - Class in org.apache.flink.streaming.api.operators
-
Describe the input selection that stream operators want to read records.
- InputSelection.Builder - Class in org.apache.flink.streaming.api.operators
-
- inputSerializer - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- inputWatermark(Watermark, int, PushingAsyncDataInput.DataOutput<?>) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
- inputWatermarkStatus(WatermarkStatus, int, PushingAsyncDataInput.DataOutput<?>) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
- INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
-
Singleton instance.
- InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
- InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunction
that takes an
Iterable
and an
AggregateFunction
.
- InternalAggregateProcessWindowFunction(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- InternalIterableAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- InternalProcessAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- internalSetKeyContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- InternalTimer<K,N> - Interface in org.apache.flink.streaming.api.operators
-
Internal interface for in-flight timers.
- InternalTimerService<N> - Interface in org.apache.flink.streaming.api.operators
-
Interface for working with time and timers.
- internalTimerService - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- InternalTimerServiceImpl<K,N> - Class in org.apache.flink.streaming.api.operators
-
- internalTimerServiceManager() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the internal timer service manager for the stream operator.
- InternalTimerServiceSerializationProxy<K> - Class in org.apache.flink.streaming.api.operators
-
Serialization proxy for the timer services for a given key-group.
- InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, ClassLoader, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when restoring timer services.
- InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when writing timer services.
- InternalTimersSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
-
A snapshot of internal timers, containing event and processing timers and the serializers to use
to write / read them.
- InternalTimersSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Empty constructor used when restoring the timers.
- InternalTimersSnapshot(TypeSerializer<K>, TypeSerializer<N>, Set<TimerHeapInternalTimer<K, N>>, Set<TimerHeapInternalTimer<K, N>>) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Constructor to use when snapshotting the timers.
- InternalTimersSnapshotReaderWriters - Class in org.apache.flink.streaming.api.operators
-
- InternalTimersSnapshotReaderWriters() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> - Interface in org.apache.flink.streaming.api.operators
-
- InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter - Interface in org.apache.flink.streaming.api.operators
-
- InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
- InternalTimeServiceManager<K> - Interface in org.apache.flink.streaming.api.operators
-
An entity keeping all the time-related services.
- InternalTimeServiceManager.Provider - Interface in org.apache.flink.streaming.api.operators
-
- InternalTimeServiceManagerImpl<K> - Class in org.apache.flink.streaming.api.operators
-
An entity keeping all the time-related services.
- InternalWindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal interface for functions that are evaluated over keyed (grouped) windows.
- InternalWindowFunction.InternalWindowContext - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
- intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns true
if this window intersects the given window or if this window is just
after or before the given window.
- intervalJoin(KeyedStream<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- IntervalJoined(KeyedStream<IN1, KEY>, KeyedStream<IN2, KEY>, long, long, boolean, boolean) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
- IntervalJoinOperator<K,T1,T2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
An
operator
to execute time-bounded stream inner joins.
- IntervalJoinOperator(long, long, boolean, boolean, OutputTag<T1>, OutputTag<T2>, TypeSerializer<T1>, TypeSerializer<T2>, ProcessJoinFunction<T1, T2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Creates a new IntervalJoinOperator.
- IntervalJoinOperator.BufferEntry<T> - Class in org.apache.flink.streaming.api.operators.co
-
A container for elements put in the left/write buffer.
- IntervalJoinOperator.BufferEntrySerializer<T> - Class in org.apache.flink.streaming.api.operators.co
-
- IntervalJoinOperator.BufferEntrySerializerSnapshot<T> - Class in org.apache.flink.streaming.api.operators.co
-
- intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- invalidate() - Method in class org.apache.flink.streaming.api.datastream.CachedDataStream
-
Invalidate the cache intermediate result of this DataStream to release the physical
resources.
- invalidateClusterDataset(AbstractID) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
-
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
- invoke(IN, SinkFunction.Context) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
Writes the given value to the sink.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Called when new data arrives to the sink, and forwards it to Socket.
- invoke(TXN, IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Write value within a transaction.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
This should not be implemented by subclasses.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Implementation of the invoke method of the SinkFunction class.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.experimental.CollectSink
-
- invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isAcceptingMails() - Method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
-
- isActive() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- isAllVerticesInSameSlotSharingGroupByDefault() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets whether to put all vertices into the same slot sharing group by default.
- isApproximateLocalRecoveryEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether approximate local recovery is enabled.
- isAutoParallelismEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isBasicType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- isCached() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Checks whether the source has been canceled or stopped.
- isChainable(StreamEdge, StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- isChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChainingEnabled - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether operator chaining is enabled.
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the enable status of change log for state backend.
- isChangelogStateBackendEnabled(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Checked the resource whether the given checkpoint was committed completely.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether checkpointing is enabled.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns true if checkpointing is enabled for the running job.
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- isCleanupTime(W, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the given time is the cleanup time for the given window.
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- isClosed - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Checks if the wrapped operator has been closed.
- isDefaultActionAvailable() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- isDynamic() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isElementLate(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Decide if a record is currently late, based on current watermark and allowed lateness.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- isEmpty() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
True if the queue is empty; otherwise false.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Checks whether the map is empty.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- isEnableCheckpointsAfterTasksFinish() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
-
Deprecated.
Method to decide whether the element signals the end of the stream.
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns true
if elements are assigned to windows based on event time, false
otherwise.
- isExactlyOnceCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isExternalizedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether checkpoints should be persisted externally.
- isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- isFailing() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isFailOnCheckpointingErrors() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- isFinalState() - Method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
-
- isFinished() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- isFinished() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- isForceUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether unaligned checkpoints are forced, despite iteration feedback.
- isForceUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether unaligned checkpoints are force-enabled.
- isGraphContainingLoops() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isIdle() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
-
- isIdle() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- isInputFinished(int) - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- isInputSelected(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Tests if the input specified by inputId
is selected.
- isInputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- isInputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
If the stream operator need to be configured with the data type they will operate on.
- isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isKeyType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a latency marker.
- isLatencyMeasurementSetup() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Indicates if latency measurement has been setup.
- isLatencyMeasurementStarted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Indicates if latency mesurement has been started.
- isLegacySource() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- isLegacySource() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
- isMailboxLoopRunning() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- isMailboxLoopRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Check if the current thread is the mailbox thread.
- isMailboxThread() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Check if the current thread is the mailbox thread.
- isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- isOutputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
If the stream operator need access to the output type information at
StreamGraph
generation.
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isRestored() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns true if the states provided by this context are restored from a checkpoint/savepoint.
- isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- isStreamSource() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
-
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- isTerminated() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Returns true if the service has been shut down, false otherwise.
- isTupleType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether unaligned checkpoints are enabled.
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether unaligned checkpoints are enabled.
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isUsingCustomRawKeyedState() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- isUsingCustomRawKeyedState() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- isUsingNonBlockingInput() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isVertexNameIncludeIndexPrefix() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark.
- isWatermarkAligned - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- isWatermarkStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark status.
- isWindowLate(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the watermark is after the end timestamp plus the allowed lateness of
the given window.
- iterate() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterate(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- ITERATION_SINK_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- ITERATION_SOURCE_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- IterativeStream<T> - Class in org.apache.flink.streaming.api.datastream
-
The iterative data stream represents the start of an iteration in a
DataStream
.
- IterativeStream(DataStream<T>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream
-
- IterativeStream.ConnectedIterativeStreams<I,F> - Class in org.apache.flink.streaming.api.datastream
-
- iterator - Variable in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
-
- iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates an iterator over the entries of this map.
- MAGIC_NUMBER - Static variable in class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
-
It is important to keep this number consistent with the number used by the StreamingCommitterStateSerializer
in Flink 1.13 and 1.14.
- Mail - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
An executable bound to a specific operator in the chain, such that it can be picked for
downstream mailbox.
- Mail(ThrowingRunnable<? extends Exception>, int, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- Mail(ThrowingRunnable<? extends Exception>, int, StreamTaskActionExecutor, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- mailbox - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
The mailbox data-structure that manages request for special actions, like timers,
checkpoints, ...
- MailboxClosedException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.MailboxClosedException
-
- MailboxController(MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
-
- MailboxDefaultAction - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
Interface for the default action that is repeatedly invoked in the mailbox-loop.
- mailboxDefaultAction - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Action that is repeatedly executed if no action request is in the mailbox.
- MailboxDefaultAction.Controller - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
This controller is a feedback interface for the default action to interact with the mailbox
execution.
- MailboxDefaultAction.Suspension - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
- MailboxExecutorFactory - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
A factory for creating mailbox executors with a given priority.
- MailboxExecutorImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of an executor service build around a mailbox-based execution model.
- MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
-
- MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor, MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
-
- MailboxMetricsController - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Mailbox metrics controller class.
- MailboxMetricsController(Histogram, Counter) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
- MailboxProcessor - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
This class encapsulates the logic of the mailbox-based execution model.
- MailboxProcessor() - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- MailboxProcessor(MailboxDefaultAction) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- MailboxProcessor(MailboxDefaultAction, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor, MailboxMetricsController) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- mailboxProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- MailboxProcessor.MailboxController - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
- mainOperator - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
the main operator that consumes the input streams of this task.
- mainOperatorOutput - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- mainOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
For iteration,
StreamIterationHead
and
StreamIterationTail
used for executing
feedback edges do not contain any operators, in which case,
mainOperatorWrapper
and
tailOperatorWrapper
are null.
- maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
-
- maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
-
- makeResultsVisible(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- map(CoMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreams
and maps the output to a common
type.
- map(CoMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreams
and maps the output to a common
type.
- map(MapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- map(MapFunction<T, R>, TypeInformation<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.
- mapGenerator(DataGenerator<K>, DataGenerator<V>, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- markActive() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- markActive() - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
- markActive() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
-
- markAlignmentEnd() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- markAlignmentEnd(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- markAlignmentStart(long, long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- markAlignmentStartAndEnd(long, long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- markAsTemporarilyIdle() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Marks the source to be temporarily idle.
- markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Marks this source as canceled or stopped.
- markCheckpointAlignedAndTransformState(InputChannelInfo, CheckpointBarrier, FunctionWithException<BarrierHandlerState, BarrierHandlerState, Exception>) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- markEnd() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
-
- markEnd() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
-
- markIdle() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
- markIdle() - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
- markIdle() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
-
- markStart() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
-
- markStart() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
-
- max(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum value of every window of the data stream at the
given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data stream at the given
field expression for every window.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream at the given
position by the given key.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream at the given field
expression by the given key.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum value of every window of the data stream at the
given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data stream at the given
field expression for every window.
- MAX_BATCH_SIZE - Static variable in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- MAX_CONCURRENT_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- MAX_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
The maximal priority for mails.
- MAX_SUPPORTED_INPUT_COUNT - Static variable in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The watermark that signifies end-of-event-time.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo data stream by the
given field expression for every window.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum element of the data stream by the given
field expression by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given
position by the given key.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given
position by the given key.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given
position by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given field.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by
the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo data stream by the
given field expression for every window.
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the largest timestamp that still belongs to this window.
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
-
Gets the largest timestamp that still belongs to this window.
- maybeInterruptOnCancel(Thread, String, Long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- maybeInterruptOnCancel(Thread, String, Long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- measureMailboxLatency() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
- merge(Collection<W>, W) - Method in interface org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner.MergeCallback
-
Specifies that the given windows should be merged into the result window.
- merge(CommittableCollector<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Merges all information from an external collector into this collector.
- merge(W, Collection<W>, W, Collection<W>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet.MergeFunction
-
This gets called when a merge occurs.
- mergedWindows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- mergePartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.OnMergeContext
-
- mergePartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- mergeWindows(Collection<W>, MergingWindowAssigner.MergeCallback<W>) - Method in class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
-
Determines which windows (if any) should be merged.
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- MergingWindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A WindowAssigner
that can merge windows.
- MergingWindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
-
- MergingWindowAssigner.MergeCallback<W> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
- MergingWindowSet<W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
- MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.streaming.runtime.operators.windowing
-
- MergingWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- MessageAcknowledgingSourceBase<Type,UId> - Class in org.apache.flink.streaming.api.functions.source
-
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
- MessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Metric group for the operator.
- metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Metric group for the operator.
- milliseconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of milliseconds.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum value of every window of the data stream
at the given position.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum value of the pojo data stream at the given
field expression for every window.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the data stream at the given
position by the given key.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the data stream at the given field
expression by the given key.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum value of every window of the data stream
at the given position.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum value of the pojo data stream at the given
field expression for every window.
- MIN_MONITORING_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
The minimum interval allowed between consecutive path scans.
- MIN_PAUSE_BETWEEN_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- MIN_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
The minimal priority for mails.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given position.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum element of the pojo data stream by the
given field expression for every window.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum element of the data stream by the given
field expression by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given
position by the given key.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given
position by the given key.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given
position by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given field.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by
the given position.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum element of the pojo data stream by the
given field expression for every window.
- minInputWatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
- minutes(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of minutes.
- MinWatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
-
- MinWatermarkGauge(WatermarkGauge...) - Constructor for class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
-
- MultiInputSortingDataInput<IN,K> - Class in org.apache.flink.streaming.api.operators.sort
-
An input that wraps an underlying input and sorts the incoming records.
- MultiInputSortingDataInput.SelectableSortingInputs - Class in org.apache.flink.streaming.api.operators.sort
-
A wrapper that combines sorting
inputs
with a
InputSelectable
that should be used to choose which input to consume next from.
- MultiInputTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
- MultiInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
-
- MultipleConnectedStreams - Class in org.apache.flink.streaming.api.datastream
-
- MultipleConnectedStreams(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
-
- MultipleFuturesAvailabilityHelper - Class in org.apache.flink.streaming.runtime.io
-
This class is semi-thread safe.
- MultipleFuturesAvailabilityHelper(int) - Constructor for class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
-
- MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> - Class in org.apache.flink.streaming.api.functions.source
-
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
- MultipleIdsMessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MultipleInputSelectionHandler - Class in org.apache.flink.streaming.runtime.io
-
- MultipleInputSelectionHandler(InputSelectable, int) - Constructor for class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
-
- MultipleInputStreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with multiple
Input
s.
- MultipleInputStreamTask<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- MultipleInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- MultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
-
- MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
-
- MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
-
- of(SerializableSupplier<SimpleVersionedSerializer<CommT>>) - Static method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- of(StreamOperator<OUT>) - Static method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
Create a SimpleOperatorFactory from existed StreamOperator.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindows
WindowAssigner
that assigns elements to
sliding time windows based on the element timestamp.
- of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindows
WindowAssigner
that assigns elements to
time windows based on the element timestamp and offset.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindows
WindowAssigner
that assigns
elements to sliding time windows based on the element timestamp.
- of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindows
WindowAssigner
that assigns elements
to time windows based on the element timestamp.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindows
WindowAssigner
that assigns elements
to time windows based on the element timestamp and offset.
- of(Time, Time, WindowStagger) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindows
WindowAssigner
that assigns elements
to time windows based on the element timestamp, offset and a staggering offset, depending on
the staggering policy.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time, Time, WindowStagger) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp, offset and a staggering offset,
depending on the staggering policy.
- of(long) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a CountEvictor
that keeps the given number of elements.
- of(long, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a CountEvictor
that keeps the given number of elements in the pane Eviction
is done before/after the window function based on the value of doEvictAfter.
- of(double, DeltaFunction<T>) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a DeltaEvictor
from the given threshold and DeltaFunction
.
- of(double, DeltaFunction<T>, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a DeltaEvictor
from the given threshold, DeltaFunction
.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a TimeEvictor
that keeps the given number of elements.
- of(Time, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a TimeEvictor
that keeps the given number of elements.
- of(long, TimeUnit) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(long) - Static method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
Creates a trigger that fires once the number of elements in a pane reaches the given count.
- of(double, DeltaFunction<T>, TypeSerializer<T>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
Creates a delta trigger from the given threshold and DeltaFunction
.
- of(Trigger<T, W>, Duration) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- of(Trigger<T, W>, Duration, boolean, boolean) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- of(Trigger<T, W>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
Creates a new purging trigger from the given Trigger
.
- of(RuntimeContext) - Static method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
- one(T1) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- OneInputStreamOperator<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with one input.
- OneInputStreamOperatorFactory<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
- OneInputStreamTask<IN,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- OneInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- OneInputStreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- OneInputTransformation<IN,OUT> - Class in org.apache.flink.streaming.api.transformations
-
- OneInputTransformation(Transformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Creates a new OneInputTransformation
from the given input and operator.
- OneInputTransformation(Transformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Creates a new LegacySinkTransformation
from the given input Transformation
.
- OneInputTransformationTranslator<IN,OUT> - Class in org.apache.flink.streaming.runtime.translators
-
- OneInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
-
- onElement(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called for every element that gets added to a pane.
- onElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
-
- onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
-
- onEventTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
-
- onEventTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- onEventTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
-
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- onEventTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when an event-time timer fires.
- onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when an event-time timer that was set using the trigger context fires.
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- onEventTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- onMerge(GlobalWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when several windows have been merged into one window by the
WindowAssigner
.
- onMerge(Collection<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onPartFileOpened(BucketID, Path) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.FileLifeCycleListener
-
Notifies a new file has been opened.
- onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
-
- onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- onProcessingTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
-
- onProcessingTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- onProcessingTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
-
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- onProcessingTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when a processing-time timer fires.
- onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when a processing-time timer that was set using the trigger context fires.
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- onTimer(long, CoProcessFunction<IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
- onTimer(long, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
- onTimer(long, KeyedCoProcessFunction<K, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
- onTimer(long, KeyedProcessFunction<K, I, O>.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
- onTimer(long, ProcessFunction<I, O>.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
-
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
-
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
-
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
-
- onWatermark(KEY, Watermark) - Method in interface org.apache.flink.streaming.api.operators.OnWatermarkCallback
-
The action to be triggered upon reception of a watermark.
- OnWatermarkCallback<KEY> - Interface in org.apache.flink.streaming.api.operators
-
A callback registered with the InternalWatermarkCallbackService
service.
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Initialize the connection with the Socket in the server.
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- open() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- open(String, FunctionInitializationContext, RuntimeContext) - Method in interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- open(Configuration) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- open() - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- open() - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
-
- open() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic.
- open() - Method in class org.apache.flink.streaming.api.operators.StreamProject
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- open(Configuration) - Method in class org.apache.flink.streaming.experimental.CollectSink
-
Initialize the connection with the Socket in the server.
- open() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Opens/connects to the resource, and possibly creates it beforehand.
- open() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- OperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
The
OperatorChain
contains all operators that are executed as one chain within a single
StreamTask
.
- OperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- operatorChain - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The chain of operators executed by this task.
- OperatorChain.ChainedSource - Class in org.apache.flink.streaming.runtime.tasks
-
Wrapper class to access the chained sources and their's outputs.
- operatorEventDispatcher - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- OperatorEventDispatcherImpl - Class in org.apache.flink.streaming.runtime.tasks
-
An implementation of the OperatorEventDispatcher
.
- OperatorEventDispatcherImpl(ClassLoader, TaskOperatorEventGateway) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
-
- operatorFactory - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- operatorId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
- OperatorSnapshotFinalizer - Class in org.apache.flink.streaming.api.operators
-
- OperatorSnapshotFinalizer(OperatorSnapshotFutures) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
-
- OperatorSnapshotFutures - Class in org.apache.flink.streaming.api.operators
-
- OperatorSnapshotFutures() - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>, Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- operatorStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the operator state backend for the stream operator.
- operatorStateBackend(String, PrioritizedOperatorSubtaskState, CloseableRegistry) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- OrderedStreamElementQueue<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
-
- OrderedStreamElementQueue(int) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- orderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- orderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- org.apache.flink.streaming.api - package org.apache.flink.streaming.api
-
- org.apache.flink.streaming.api.checkpoint - package org.apache.flink.streaming.api.checkpoint
-
- org.apache.flink.streaming.api.connector.sink2 - package org.apache.flink.streaming.api.connector.sink2
-
- org.apache.flink.streaming.api.datastream - package org.apache.flink.streaming.api.datastream
-
- org.apache.flink.streaming.api.environment - package org.apache.flink.streaming.api.environment
-
- org.apache.flink.streaming.api.functions - package org.apache.flink.streaming.api.functions
-
- org.apache.flink.streaming.api.functions.aggregation - package org.apache.flink.streaming.api.functions.aggregation
-
- org.apache.flink.streaming.api.functions.async - package org.apache.flink.streaming.api.functions.async
-
- org.apache.flink.streaming.api.functions.co - package org.apache.flink.streaming.api.functions.co
-
- org.apache.flink.streaming.api.functions.query - package org.apache.flink.streaming.api.functions.query
-
- org.apache.flink.streaming.api.functions.sink - package org.apache.flink.streaming.api.functions.sink
-
- org.apache.flink.streaming.api.functions.sink.filesystem - package org.apache.flink.streaming.api.functions.sink.filesystem
-
- org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
-
- org.apache.flink.streaming.api.functions.source.datagen - package org.apache.flink.streaming.api.functions.source.datagen
-
- org.apache.flink.streaming.api.functions.timestamps - package org.apache.flink.streaming.api.functions.timestamps
-
- org.apache.flink.streaming.api.functions.windowing - package org.apache.flink.streaming.api.functions.windowing
-
- org.apache.flink.streaming.api.functions.windowing.delta - package org.apache.flink.streaming.api.functions.windowing.delta
-
- org.apache.flink.streaming.api.functions.windowing.delta.extractor - package org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
- org.apache.flink.streaming.api.graph - package org.apache.flink.streaming.api.graph
-
- org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
-
- org.apache.flink.streaming.api.operators.async - package org.apache.flink.streaming.api.operators.async
-
- org.apache.flink.streaming.api.operators.async.queue - package org.apache.flink.streaming.api.operators.async.queue
-
- org.apache.flink.streaming.api.operators.co - package org.apache.flink.streaming.api.operators.co
-
- org.apache.flink.streaming.api.operators.collect - package org.apache.flink.streaming.api.operators.collect
-
- org.apache.flink.streaming.api.operators.sort - package org.apache.flink.streaming.api.operators.sort
-
- org.apache.flink.streaming.api.operators.sorted.state - package org.apache.flink.streaming.api.operators.sorted.state
-
- org.apache.flink.streaming.api.operators.source - package org.apache.flink.streaming.api.operators.source
-
- org.apache.flink.streaming.api.operators.util - package org.apache.flink.streaming.api.operators.util
-
- org.apache.flink.streaming.api.transformations - package org.apache.flink.streaming.api.transformations
-
- org.apache.flink.streaming.api.watermark - package org.apache.flink.streaming.api.watermark
-
- org.apache.flink.streaming.api.windowing.assigners - package org.apache.flink.streaming.api.windowing.assigners
-
- org.apache.flink.streaming.api.windowing.evictors - package org.apache.flink.streaming.api.windowing.evictors
-
- org.apache.flink.streaming.api.windowing.time - package org.apache.flink.streaming.api.windowing.time
-
- org.apache.flink.streaming.api.windowing.triggers - package org.apache.flink.streaming.api.windowing.triggers
-
- org.apache.flink.streaming.api.windowing.windows - package org.apache.flink.streaming.api.windowing.windows
-
- org.apache.flink.streaming.experimental - package org.apache.flink.streaming.experimental
-
This package holds classes that are experimental.
- org.apache.flink.streaming.runtime.io - package org.apache.flink.streaming.runtime.io
-
- org.apache.flink.streaming.runtime.io.checkpointing - package org.apache.flink.streaming.runtime.io.checkpointing
-
- org.apache.flink.streaming.runtime.io.recovery - package org.apache.flink.streaming.runtime.io.recovery
-
- org.apache.flink.streaming.runtime.metrics - package org.apache.flink.streaming.runtime.metrics
-
- org.apache.flink.streaming.runtime.operators - package org.apache.flink.streaming.runtime.operators
-
This package contains the operators that perform the stream transformations.
- org.apache.flink.streaming.runtime.operators.sink - package org.apache.flink.streaming.runtime.operators.sink
-
- org.apache.flink.streaming.runtime.operators.sink.committables - package org.apache.flink.streaming.runtime.operators.sink.committables
-
- org.apache.flink.streaming.runtime.operators.util - package org.apache.flink.streaming.runtime.operators.util
-
- org.apache.flink.streaming.runtime.operators.windowing - package org.apache.flink.streaming.runtime.operators.windowing
-
This package contains the operators that implement the various window operations on data streams.
- org.apache.flink.streaming.runtime.operators.windowing.functions - package org.apache.flink.streaming.runtime.operators.windowing.functions
-
- org.apache.flink.streaming.runtime.partitioner - package org.apache.flink.streaming.runtime.partitioner
-
- org.apache.flink.streaming.runtime.streamrecord - package org.apache.flink.streaming.runtime.streamrecord
-
- org.apache.flink.streaming.runtime.tasks - package org.apache.flink.streaming.runtime.tasks
-
This package contains classes that realize streaming tasks.
- org.apache.flink.streaming.runtime.tasks.mailbox - package org.apache.flink.streaming.runtime.tasks.mailbox
-
- org.apache.flink.streaming.runtime.translators - package org.apache.flink.streaming.runtime.translators
-
- org.apache.flink.streaming.runtime.watermarkstatus - package org.apache.flink.streaming.runtime.watermarkstatus
-
- org.apache.flink.streaming.util - package org.apache.flink.streaming.util
-
- org.apache.flink.streaming.util.functions - package org.apache.flink.streaming.util.functions
-
- org.apache.flink.streaming.util.graph - package org.apache.flink.streaming.util.graph
-
- org.apache.flink.streaming.util.keys - package org.apache.flink.streaming.util.keys
-
- org.apache.flink.streaming.util.retryable - package org.apache.flink.streaming.util.retryable
-
- org.apache.flink.streaming.util.serialization - package org.apache.flink.streaming.util.serialization
-
- org.apache.flink.streaming.util.typeutils - package org.apache.flink.streaming.util.typeutils
-
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
-
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Emits a record to the side output identified by the OutputTag
.
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
-
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- Output<T> - Interface in org.apache.flink.streaming.api.operators
-
A
StreamOperator
is supplied with an object of
this interface that can be used to emit elements and other messages, such as barriers and
watermarks, from an operator.
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
-
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- output(OutputTag<X>, X) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- OutputFormatOperatorFactory<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for operator factories which create the sink operator containing an OutputFormat
.
- OutputFormatSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- OutputFormatSinkFunction(OutputFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- OutputTypeConfigurable<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Stream operators can implement this interface if they need access to the output type information
at
StreamGraph
generation.
- owner - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
-
- PACT - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- ParallelSourceFunction<OUT> - Interface in org.apache.flink.streaming.api.functions.source
-
A stream data source that is executed in parallel.
- partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
- PartitionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a change of partitioning of the input elements.
- PartitionTransformation(Transformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- PartitionTransformation(Transformation<T>, StreamPartitioner<T>, StreamExchangeMode) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- PartitionTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
- PartitionTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
-
- PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- PassThroughWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- path - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- peek() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- pendingCheckpoints - Variable in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
The list with IDs from checkpoints that were triggered, but not yet completed or notified of
completion.
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- pendingTransaction - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- pendingTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- PeriodTimer - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
Interface for the measurement of the period of time.
- persist() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Persist the updated mapping to the given state if the mapping changed since initialization.
- PerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
-
- PhysicalTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
A Transformation
that creates a physical operation.
- poll() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- pollNext() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
- preCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Pre commit previously created transaction.
- PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?>, CloseableRegistry) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- prepareClose() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Lifecycle method to close the mailbox for action submission.
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
-
- prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
-
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
-
- prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
-
Prepares to spill the in-flight input buffers as checkpoint snapshot.
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
-
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- prepareSnapshotPreBarrier(long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called when the operator should do a snapshot, before it emits its own
checkpoint barrier.
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- print(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- PrintSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Sink implementation writing every element to the standard output or standard error stream.
- PrintSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink function that prints to STDOUT.
- PrintSink(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT or STDERR.
- PrintSink(String) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT and gives a sink identifier.
- PrintSink(String, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT or STDERR and gives a sink identifier.
- PrintSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Implementation of the SinkFunction writing every tuple to the standard output or standard error
stream.
- PrintSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(String, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out and gives a sink identifier.
- printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard error stream (stderr).
- printToErr(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard error stream (stderr).
- process(ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(BroadcastProcessFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(BroadcastProcessFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(CoProcessFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams, thereby creating
a transformed output stream.
- process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams, thereby creating
a transformed output stream.
- process(KeyedCoProcessFunction<K, IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
KeyedCoProcessFunction
on the connected input keyed streams,
thereby creating a transformed output stream.
- process(KeyedCoProcessFunction<K, IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
KeyedCoProcessFunction
on the connected input streams, thereby
creating a transformed output stream.
- process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunction
on the input stream, thereby creating a transformed
output stream.
- process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunction
on the input stream, thereby creating a transformed
output stream.
- process(ProcessJoinFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Completes the join operation with the given user function that is executed for each
joined pair of elements.
- process(ProcessJoinFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Completes the join operation with the given user function that is executed for each
joined pair of elements.
- process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- process(KeyedProcessFunction<KEY, T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunction
on the input stream, thereby creating a
transformed output stream.
- process(KeyedProcessFunction<KEY, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunction
on the input stream, thereby creating a
transformed output stream.
- process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
- ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
- ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- processBroadcastElement(IN2, BroadcastProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
- processBroadcastElement(IN2, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
- processBuffer(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- processContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- processElement(IN1, BroadcastProcessFunction<IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
data stream
.
- processElement(IN1, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
keyed stream
.
- processElement(IN1, IN2, ProcessJoinFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
-
This method is called for each joined pair of elements.
- processElement(I, KeyedProcessFunction<K, I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
Process one element from the input stream.
- processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
-
Process one element from the input stream.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
-
- processElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.Input
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamProject
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator
-
- processElement1(IN1, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(IN1, KeyedCoProcessFunction<K, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement1(StreamRecord<T1>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- processElement1(StreamRecord<IN1>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the first input of this two-input operator.
- processElement2(IN2, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(IN2, KeyedCoProcessFunction<K, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement2(StreamRecord<T2>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- processElement2(StreamRecord<IN2>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the second input of this two-input operator.
- processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
-
- processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- processEvent(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- processEvent(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
-
- ProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
-
A function that processes elements of a stream.
- ProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction
-
- ProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
-
- ProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
-
- ProcessingTimeoutTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- ProcessingTimeService - Interface in org.apache.flink.streaming.runtime.tasks
-
Defines the current processing time and handles all related actions, such as register timers for
tasks to be executed in the future.
- ProcessingTimeServiceAware - Interface in org.apache.flink.streaming.runtime.tasks
-
- ProcessingTimeServiceFactory - Interface in org.apache.flink.streaming.runtime.tasks
-
A factory for creating processing time services with a given MailboxExecutor
.
- ProcessingTimeServiceUtil - Class in org.apache.flink.streaming.runtime.tasks
-
- ProcessingTimeServiceUtil() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
-
- ProcessingTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the current processing
time.
- ProcessingTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- ProcessingTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the current system time passes the end of the window to which a
pane belongs.
- processInput() - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
-
- processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
-
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
This method implements the default action of the task (e.g.
- ProcessJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes two joined elements and produces a single output one.
- ProcessJoinFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
-
- ProcessJoinFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
-
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
LatencyMarker
that arrived on the first input of this two-input operator.
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- processLatencyMarker1(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker1(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the first input of this two-input operator.
- processLatencyMarker2(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker2(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the second input of this two-input
operator.
- ProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- ProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
Watermark
that arrived on the first input of this two-input operator.
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
Override the base implementation to completely ignore watermarks propagated from upstream,
except for the "end of time" watermark.
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark1(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the first input of this two-input operator.
- processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark2(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the second input of this two-input operator.
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
-
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermarkStatus(WatermarkStatus, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- processWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.Input
-
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
Override the base implementation to completely ignore statuses propagated from upstream.
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- processWatermarkStatus1(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermarkStatus1(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
WatermarkStatus
that arrived on the first input of this two-input
operator.
- processWatermarkStatus2(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermarkStatus2(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
WatermarkStatus
that arrived on the second input of this two-input
operator.
- ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
- ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
- ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- ProgressiveTimestampsAndWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
-
An implementation of
TimestampsAndWatermarks
that does periodic watermark emission and
keeps track of watermarks on a per-split basis.
- ProgressiveTimestampsAndWatermarks(TimestampAssigner<T>, WatermarkGeneratorSupplier<T>, WatermarkGeneratorSupplier.Context, ProcessingTimeService, Duration) - Constructor for class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
-
- project(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates a Project transformation on a
Tuple
DataStream
.
Note: Only Tuple DataStreams can be projected.
- projectTuple1() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
Tuple
DataStream
to the previously selected fields.
- projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- Provider(OperatorID, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
-
- PurgingTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A trigger that can turn any
Trigger
into a purging
Trigger
.
- PushingAsyncDataInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
The variant of
PullingAsyncDataInput
that is defined for handling both network input and
source input in a unified way via
PushingAsyncDataInput.emitNext(DataOutput)
instead of returning
Optional.empty()
via
PullingAsyncDataInput.pollNext()
.
- PushingAsyncDataInput.DataOutput<T> - Interface in org.apache.flink.streaming.runtime.io
-
Basic data output interface used in emitting the next element from data input.
- put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts the given value, mapped under the given key.
- put(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Enqueues the given mail to the mailbox and blocks until there is capacity for a successful
put.
- put(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- putFirst(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Adds the given action to the head of the mailbox.
- putFirst(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- putIfAbsent(K, KeyMap.LazyFactory<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts a value for the given key, if no value is yet contained for that key.
- putOrAggregate(K, V, ReduceFunction<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts or aggregates a value into the hash map.
- random - Variable in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- RandomGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
-
Random generator.
- RandomGenerator() - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- rawKeyedStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that
are assigned to this operator.
- rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- rawOperatorStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions
that are assigned to this stream operator.
- rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- read(DataInputView, boolean) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.ReadOnlyContext
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
- readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- readTextFile(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readTimersSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
-
Reads a timers snapshot from the provided input view.
- readVersionAndDeserializeList(SimpleVersionedSerializer<T>, DataInputView) - Static method in class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
-
- 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
-
- recordDeserializers - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- RecordProcessorUtils - Class in org.apache.flink.streaming.runtime.io
-
- recordWriter - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
-
Implementation of
Output
that sends data using a
RecordWriter
.
- RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- RecoverableStreamTaskInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
- recoverAndAbort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Abort a transaction that was rejected by a coordinator after a failure.
- recoverAndCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Invoked on recovered transactions after a failure.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a reduce transformation on the grouped data stream grouped on by the given key
position.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
AllWindowFunction
that is used for implementing a fold on a window configuration
that only allows
AllWindowFunction
and cannot directly execute a
ReduceFunction
.
- ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
WindowFunction
that is used for implementing a fold on a window configuration
that only allows
WindowFunction
and cannot directly execute a
ReduceFunction
.
- ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- ReduceTransformation<IN,K> - Class in org.apache.flink.streaming.api.transformations
-
A
Transformation
that describes a reduce operation on a
KeyedStream
.
- ReduceTransformation(String, int, Transformation<IN>, ReduceFunction<IN>, KeySelector<IN, K>, TypeInformation<K>, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- ReduceTransformationTranslator<IN,KEY> - Class in org.apache.flink.streaming.runtime.translators
-
- ReduceTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
-
- registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCacheTransformation(AbstractID, CacheTransformation<T>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- registerCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Registers a timer to cleanup the content of the window.
- registerCollectIterator(CollectResultIterator<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- registerEventHandler(OperatorID, OperatorEventHandler) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
-
- registerEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when event time watermark passes the given time.
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when the event time watermark passes the given time.
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register an event-time callback.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerJobListener(JobListener) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Register a JobListener
in this environment.
- registerJobStatusHook(JobStatusHook) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Registers the JobStatusHook.
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- registerProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register a system time callback.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Register a slot sharing group with its resource spec.
- registerTask(Callable<?>, Duration) - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.DelayableTimer
-
Register a task to be executed some time later.
- registerTimer(long, ProcessingTimeService.ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
Registers a task to be executed no sooner than time timestamp
, but without strong
guarantees of order.
- registerTimer(long, ProcessingTimeService.ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- registerType(Class<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given Serializer via its class as a serializer for the given type at the
KryoSerializer.
- RegularOperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
- RegularOperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- releaseDeserializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
- 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.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[], SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteStreamEnvironment(PipelineExecutorServiceLoader, String, int, Configuration, String[], URL[], SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- remove() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- remove(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- replace(X) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value.
- replace(X, long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value and the currently stored timestamp
with the new timestamp.
- reportLatency(LatencyMarker) - Method in class org.apache.flink.streaming.util.LatencyStats
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- reportThrowable(Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Reports a throwable for rethrowing from the mailbox thread.
- reportWatermark(Watermark, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- requiresSorting(StreamConfig.InputConfig) - Static method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- 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
-
- RescalingStreamTaskNetworkInput<T> - Class in org.apache.flink.streaming.runtime.io.recovery
-
- RescalingStreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
-
- reset() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
Clear the whole buffer and discard all results.
- resetAlignment() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
-
- resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Statements to be executed after writing a batch goes here.
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
Deprecated.
- resetSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
Sets the state of the split to null
.
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- resetToUnAvailable() - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
-
- resolveCheckpoint(String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
-
- resolveOuterSchemaCompatibility(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- restore() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
-
- restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
-
- restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Deprecated.
Restores the state of the function or operator to that of a previous checkpoint.
- restoreTimersForKeyGroup(InternalTimersSnapshot<?, ?>, int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Restore the timers (both processing and event time ones) for a given keyGroupIdx
.
- ResultFuture<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
ResultFuture
collects data / error in user codes while processing async i/o.
- resultPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryPredicate
-
An Optional Java that defines a condition on asyncFunction's future result which
will trigger a later reattempt operation, will be called before user's ResultFuture#complete.
- resume() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Suspension
-
Resume execution of the default action.
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- retireWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Removes the given window from the set of in-flight windows.
- retryLater() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- RetryPredicates - Class in org.apache.flink.streaming.util.retryable
-
Utility class to create concrete retry predicates.
- RetryPredicates() - Constructor for class org.apache.flink.streaming.util.retryable.RetryPredicates
-
- 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.
- revert(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
Revert the buffer back to the result whose offset is `checkpointedOffset`.
- RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
-
- RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
-
- RichAsyncFunction() - Constructor for class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- RichCoFlatMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
- RichCoFlatMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
-
- RichCoMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoMapFunction represents a Map transformation with two different input types.
- RichCoMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoMapFunction
-
- RichParallelSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
Base class for implementing a parallel data source.
- RichParallelSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction
-
- RichProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
-
Deprecated.
- RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
-
Deprecated.
- 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
-
Base class for implementing a parallel data source that has access to context information (via
AbstractRichFunction.getRuntimeContext()
) and additional life-cycle methods (AbstractRichFunction.open(org.apache.flink.configuration.Configuration)
and AbstractRichFunction.close()
.
- RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichSourceFunction
-
- RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
-
- RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>, RollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- run(SourceFunction.SourceContext<T>) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Starts the source.
- run(SourceFunction.SourceContext<Long>) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- run(Object, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run(Object, Output<StreamRecord<OUT>>, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- run(RunnableWithException) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
- run(RunnableWithException) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- runDefaultAction(MailboxDefaultAction.Controller) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction
-
This method implements the default action of the mailbox loop (e.g.
- runExclusively(Runnable) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Runs the given code exclusively on this mailbox.
- runExclusively(Runnable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- runMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Runs the mailbox processing loop.
- runMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Execute a single (as small as possible) step of the mailbox.
- runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- runThrowing(ThrowingRunnable<E>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
- runThrowing(ThrowingRunnable<E>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- savepoint() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- ScalaProductFieldAccessorFactory - Interface in org.apache.flink.streaming.util.typeutils
-
Interface to interact with optional Scala field accessors.
- scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly at a fixed rate.
- scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly with a fixed delay.
- scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- SECOND - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The InputSelection
instance which indicates to select the second input.
- seconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of seconds.
- select(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
-
Selects an input identified by the given inputId
.
- SelectableSortingInputs(StreamTaskInput<?>[], StreamTaskInput<?>[], InputSelectable) - Constructor for class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
Note: Broadcast mode could be handled directly for all the output channels in record writer,
so it is no need to select channels via this method.
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- self() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
-
Deprecated.
- sendAcknowledgeCheckpointEvent(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
Write the given element into the backend.
- SequenceGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
-
A stateful, re-scalable
DataGenerator
that emits each number from a given interval
exactly once, possibly in parallel.
- SequenceGenerator(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
Creates a DataGenerator that emits all numbers from the given interval exactly once.
- SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
-
- serialize(CommittableMessage<CommT>) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
-
- serialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- serialize(IntervalJoinOperator.BufferEntry<T>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
-
- serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
-
- serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- serialize(GlobalWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- serialize(CommittableCollector<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
-
- serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- serialize(T) - Method in interface org.apache.flink.streaming.util.serialization.SerializationSchema
-
Deprecated.
Serializes the incoming element to a specified type.
- serializeAccumulatorResult(long, String, long, List<byte[]>) - Static method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- serializeAllConfigs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Serialize all object configs synchronously.
- SERIALIZEDUDF - Static variable in class org.apache.flink.streaming.api.graph.StreamConfig
-
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- serializer - Variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- sessionIds - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionIdsPerSnapshot - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- SessionWindowTimeGapExtractor<T> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
A SessionWindowTimeGapExtractor
extracts session time gaps for Dynamic Session Window
Assigners.
- set(T, F) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Sets the field (specified in the constructor) of the given record to the given value.
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setAlignedCheckpointTimeout(Duration) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Only relevant if ExecutionCheckpointingOptions.ENABLE_UNALIGNED
is enabled.
- setAlignedCheckpointTimeout(Duration) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setAlignmentTimeout(Duration) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- setAllVerticesInSameSlotSharingGroupByDefault(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Set whether to put all vertices into the same slot sharing group by default.
- setAndSerializeTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setAutoParallelismEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setBoundedness(Boundedness) - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
Mutable for legacy sources in the Table API.
- setBucketLifeCycleListener(BucketLifeCycleListener<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the buffering timeout for data produced by this operation.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- 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
-
- setCached(boolean) - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
-
- setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainIndex(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
-
Deprecated.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Set the chaining strategy for operator factory.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
-
Sets the chaining strategy of this Transformation
.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
- 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.TimestampsAndWatermarksTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChangelogStateBackendEnabled(TernaryBoolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChangelogStateBackendEnabled(TernaryBoolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setChangelogStateBackendEnabled(TernaryBoolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setCheckpointIdOfIgnoredInFlightData(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Setup the checkpoint id for which the in-flight data will be ignored for all operators in
case of the recovery from this checkpoint.
- 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
-
- setCheckpointStorage(CheckpointStorage) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
CheckpointStorage defines how StateBackend
's checkpoint their state for fault
tolerance in streaming applications.
- setCheckpointStorage(String) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Configures the application to write out checkpoint snapshots to the configured directory.
- setCheckpointStorage(URI) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Configures the application to write out checkpoint snapshots to the configured directory.
- setCheckpointStorage(Path) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Configures the application to write out checkpoint snapshots to the configured directory.
- setCheckpointStorage(CheckpointStorage) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointStorage(CheckpointStorage) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum time that a checkpoint may take before being discarded.
- setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
-
Sets the checkpoint trigger through which the source can trigger the checkpoint.
- setCoLocationGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setCommitterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the committer operator used to recover state.
- 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
-
- setConsumeClusterDatasetId(IntermediateDataSetID) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setContext(Optional<CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setCoordinatorListeningID(String) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- setCoordinatorListeningID(String) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- setCurrentKey(K) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
-
- setCurrentKey(K) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- setCurrentTime(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- setCurrentWatermark(long) - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
-
- setDefaultBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setDefaultSavepointDirectory(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
- setDefaultSavepointDirectory(URI) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
- setDefaultSavepointDirectory(Path) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
- setDescription(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the description for this sink.
- setDescription(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the description for this operation.
- setDynamic(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setEnableCheckpointsAfterTasksFinish(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setEventTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setExternalizedCheckpointCleanup(CheckpointConfig.ExternalizedCheckpointCleanup) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the mode for externalized checkpoint clean-up.
- setFailOnCheckpointingErrors(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- setFileLifeCycleListener(FileLifeCycleListener<BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- setForceUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether unaligned checkpoints are forced, despite currently non-checkpointable
iteration feedback or custom partitioners.
- setGlobalCommitterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the global committer operator used to recover state.
- setGlobalStreamExchangeMode(GlobalStreamExchangeMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setGraphContainingLoops(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setInputs(StreamConfig.InputConfig...) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
- setInternalIndex(int) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- setInternalIndex(int) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
-
- setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
-
- setJobId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the job ID after instantiation.
- setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setJobType(JobType) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setKeyContextElement(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
-
- setKeyContextElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Set the correct key context before processing the record
.
- setKeyContextElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
- setKeyContextElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
-
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement1(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement2(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setKeyedStateStore(KeyedStateStore) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- setKeySerializerSnapshot(TypeSerializerSnapshot<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setLatencyMeasurementInterval(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
- setMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- setMailboxExecutor(MailboxExecutor) - Method in interface org.apache.flink.streaming.api.operators.YieldingOperatorFactory
-
- setManagedMemoryFractionOperatorOfUseCase(ManagedMemoryUseCase, double) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Fraction of managed memory reserved for the given use case that this operator should use.
- setManagedMemoryUseCaseWeights(int, Map<ManagedMemoryUseCase, Integer>, Set<ManagedMemoryUseCase>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setManagedMemoryUseCaseWeights(Map<ManagedMemoryUseCase, Integer>, Set<ManagedMemoryUseCase>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum parallelism of this operator.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum degree of parallelism defined for the program.
- setMaxParallelism(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setMaxSubtasksPerChannelStateFile(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
The number of subtasks to share the same channel state file.
- setMaxSubtasksPerChannelStateFile(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the minimal pause between checkpointing attempts.
- setMultipleInputStateKey(Integer, List<KeySelector<?, ?>>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setNumberOfNetworkInputs(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
-
- setOperatorDescription(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setOperatorEventGateway(OperatorEventGateway) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- setOperatorID(OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOperatorId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the operator ID after instantiation.
- setOperatorName(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOperatorNonChainedOutputs(List<NonChainedOutput>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Sets the operator level non-chained outputs.
- setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setOutputFormat(Integer, OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOutputFormat(OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
-
- setOutputType(TypeInformation<T>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Set element type and re-serialize element if required.
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
-
Is called by the
org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer,
String, StreamOperator, TypeInformation, TypeInformation, String)
method when the
StreamGraph
is generated.
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
- setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- 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, int, boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- setPartitionType(ResultPartitionType) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- setPendingCommitTransactions(List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setPendingTransaction(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
- setProcessingTimeService(ProcessingTimeService) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware
-
- setProcessingTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setResources(int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the restart strategy configuration.
- setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- setRuntimeMode(RuntimeExecutionMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the runtime execution mode for the application (see RuntimeExecutionMode
).
- setSavepointDir(Path) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setSavepointDir(Path) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setSavepointDirectory(Path) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSerializersIn(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSlotSharingGroupResource(Map<String, ResourceProfile>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSlotSharingGroupResource(Map<String, ResourceProfile>) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
Specify fine-grained resource requirements for slot sharing groups.
- setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split.
- setSplitState(Serializable) - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
Sets the state of the split.
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the state backend that describes how to store operator.
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setStateBackendUsesManagedMemory(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Sets the KeySelector
that must be used for partitioning keyed state of this Sink.
- 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.
- 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.LegacySinkTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStatePartitioners(KeySelector<?, ?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStreamOperatorFactory(StreamOperatorFactory<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setSupportsConcurrentExecutionAttempts(Integer, boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSupportsConcurrentExecutionAttempts(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSupportsConcurrentExecutionAttempts(boolean) - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
-
- setSupportsUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- setSynchronousSavepoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setTimerServiceProvider(InternalTimeServiceManager.Provider) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTimerServiceProvider(InternalTimeServiceManager.Provider) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- setTolerableCheckpointFailureNumber(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
This defines how many consecutive checkpoint failures will be tolerated, before the whole job
is failed over.
- setTransactionTimeout(long) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Sets the transaction timeout.
- setTransformationUID(Integer, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets an user provided hash for this operator.
- setUnalignedCheckpointsEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
-
Deprecated.
Initializes the operator.
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- SetupableStreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
- setupLatencyMeasurement(TimerService, MailboxExecutor) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Sets up latency measurement with required
TimerService
and
MailboxExecutor
.
- setupNetworkInputs(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setupNumRecordsInCounter(StreamOperator) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- setUserHash(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setVertexDescriptionMode(PipelineOptions.VertexDescriptionMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setVertexNameIncludeIndexPrefix(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setVertexNonChainedOutputs(List<NonChainedOutput>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Sets the job vertex level non-chained outputs.
- setWriterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the writer operator used to recover state.
- SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements are shuffled
uniformly randomly to the next operation.
- ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by selecting one output channel randomly.
- ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- shutdownService() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- shutdownServiceUninterruptible(long) - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Shuts down and clean up the timer service provider hard and immediately.
- SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- sideOutput(T, long, boolean) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Write skipped late arriving element to SideOutput.
- sideOutput(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Write skipped late arriving element to SideOutput.
- SideOutputDataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
- SideOutputDataStream(StreamExecutionEnvironment, SideOutputTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SideOutputDataStream
-
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Send late arriving data to the side output identified by the given OutputTag
.
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Send late arriving data to the side output identified by the given OutputTag
.
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- sideOutputLeftLateData(OutputTag<IN1>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Send late arriving left-side data to the side output identified by the given OutputTag
.
- sideOutputRightLateData(OutputTag<IN2>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Send late arriving right-side data to the side output identified by the given OutputTag
.
- SideOutputTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of a side output of an upstream operation with a given
OutputTag
.
- SideOutputTransformation(Transformation<?>, OutputTag<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- SideOutputTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
- SideOutputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
-
- signalAlreadyCommitted() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- signalFailedWithKnownReason(Throwable) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- signalFailedWithUnknownReason(Throwable) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
-
- SimpleInputFormatOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Input format source operator factory which just wrap existed
StreamSource
.
- SimpleInputFormatOperatorFactory(StreamSource<OUT, InputFormatSourceFunction<OUT>>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
-
- SimpleOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
- SimpleOperatorFactory(StreamOperator<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
- SimpleOutputFormatOperatorFactory<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A simple operator factory which create an operator containing an OutputFormat
.
- SimpleOutputFormatOperatorFactory(OutputFormat<IN>, StreamOperator<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
-
- SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
-
- SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
Deprecated.
- SimpleStringSchema(Charset) - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
Deprecated.
Creates a new SimpleStringSchema that uses the given charset to convert between strings and
bytes.
- SimpleTimerService - Class in org.apache.flink.streaming.api
-
- SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
-
- SimpleTransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - Class in org.apache.flink.streaming.api.graph
-
A base class for all
TransformationTranslators
who translate
Transformations
that have a single operator in their runtime
implementation.
- SimpleTransformationTranslator() - Constructor for class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
- SimpleUdfStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
- SimpleUdfStreamOperatorFactory(AbstractUdfStreamOperator<OUT, ?>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
-
- SimpleVersionedListState<T> - Class in org.apache.flink.streaming.api.operators.util
-
A ListState
that uses a SimpleVersionedSerializer
instead of a TypeSerializer
.
- SimpleVersionedListState(ListState<byte[]>, SimpleVersionedSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
Creates a new SimpleVersionedListState that reads and writes bytes from the given raw
ListState with the given serializer.
- SingleCheckpointBarrierHandler - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
SingleCheckpointBarrierHandler
is used for triggering checkpoint while reading the first
barrier and keeping track of the number of received barriers and consumed barriers.
- SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
-
SingleOutputStreamOperator
represents a user defined transformation applied on a
DataStream
with one predefined output type.
- SingleOutputStreamOperator(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- SinkContextUtil - Class in org.apache.flink.streaming.api.functions.sink
-
- SinkContextUtil() - Constructor for class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
-
- SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
-
Interface for implementing user defined sink functionality.
- SinkFunction.Context - Interface in org.apache.flink.streaming.api.functions.sink
-
Context that
SinkFunctions
can use for getting additional data about an
input record.
- SinkOperatorUidHashesBuilder() - Constructor for class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
-
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
-
- sinkTo(Sink<T, ?, ?, ?>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given Sink
to this DataStream.
- sinkTo(Sink<T, ?, ?, ?>, CustomSinkOperatorUidHashes) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given Sink
to this DataStream.
- sinkTo(Sink<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given Sink
to this DataStream.
- sinkTo(Sink<T>, CustomSinkOperatorUidHashes) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given Sink
to this DataStream.
- SinkTransformation<InputT,OutputT> - Class in org.apache.flink.streaming.api.transformations
-
A Transformation
for Sink
.
- SinkTransformation(DataStream<InputT>, Sink<InputT>, TypeInformation<OutputT>, String, int, boolean, CustomSinkOperatorUidHashes) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- SinkTransformationTranslator<Input,Output> - Class in org.apache.flink.streaming.runtime.translators
-
- SinkTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
-
- SinkV1Adapter<InputT,CommT,WriterStateT,GlobalCommT> - Class in org.apache.flink.streaming.api.transformations
-
Translates Sink V1 into Sink V2.
- SinkV1Adapter.GlobalCommitterAdapter - Class in org.apache.flink.streaming.api.transformations
-
Simulate the global committer behaviour with a committer.
- SinkV1CommittableDeserializer - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
This class offers the possibility to deserialize committables that have been written with older
Flink releases (i.e.
- SinkV1CommittableDeserializer() - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
-
- SinkWriterOperatorFactory<InputT,CommT> - Class in org.apache.flink.streaming.runtime.operators.sink
-
- SinkWriterOperatorFactory(Sink<InputT>) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
-
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- size() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Return the size of the queue.
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the number of elements currently in the map.
- size() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns the current number of mails in this mailbox.
- size() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- size() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
- SlidingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the timestamp of the
elements.
- SlidingEventTimeWindows(long, long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the current system
time of the machine the operation is running on.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- slotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
-
- snapshotChannelStates(StreamOperator<?>, ChannelStateWriter.ChannelStateWriteResult, OperatorSnapshotFutures) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when a snapshot for a checkpoint is requested.
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Deprecated.
Gets the current state of the function.
- snapshotState(long, ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
- snapshotState(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state, which want to participate in a snapshot need to override this
hook method.
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Stream operators with state, which want to participate in a snapshot need to override this
hook method.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to draw a state snapshot from the operator.
- snapshotState(StateSnapshotContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
-
- snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator, Optional<InternalTimeServiceManager<?>>, String, long, long, CheckpointOptions, CheckpointStreamFactory, boolean) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
-
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
-
- snapshotTimersForKeyGroup(int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx
.
- snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Snapshots the timers to raw keyed state.
- snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
-
- snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
-
- SOCKET_TIMEOUT - Static variable in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
-
- SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Socket client that acts as a streaming sink.
- SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink.
- SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of
times.
- SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of
times.
- SocketStreamIterator<T> - Class in org.apache.flink.streaming.experimental
-
An iterator that returns the data from a socket stream.
- SocketStreamIterator(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with automatic port and bind
address.
- SocketStreamIterator(int, InetAddress, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with custom port and bind
address.
- socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int, char) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- SocketTextStreamFunction - Class in org.apache.flink.streaming.api.functions.source
-
A source function that reads strings from a socket.
- SocketTextStreamFunction(String, int, String, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SocketTextStreamFunction(String, int, String, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SortingDataInput<T,K> - Class in org.apache.flink.streaming.api.operators.sort
-
A
StreamTaskInput
which sorts in the incoming records from a chained input.
- SortingDataInput(StreamTaskInput<T>, TypeSerializer<T>, TypeSerializer<K>, KeySelector<T, K>, MemoryManager, IOManager, boolean, double, Configuration, TaskInvokable, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.operators.sort.SortingDataInput
-
- SourceFunction<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Base interface for all stream data sources in Flink.
- SourceFunction.SourceContext<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Interface that source functions use to emit elements, and possibly watermarks.
- SourceInputConfig(StreamEdge) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
-
- SourceOperator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.streaming.api.operators
-
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
- SourceOperator(FunctionWithException<SourceReaderContext, SourceReader<OUT, SplitT>, Exception>, OperatorEventGateway, SimpleVersionedSerializer<SplitT>, WatermarkStrategy<OUT>, ProcessingTimeService, Configuration, String, boolean, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperator
-
- SourceOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
- SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean, int) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
-
- SourceOperatorStreamTask<T> - Class in org.apache.flink.streaming.runtime.tasks
-
- SourceOperatorStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
-
- SourceOperatorStreamTask.AsyncDataOutputToOutput<T> - Class in org.apache.flink.streaming.runtime.tasks
-
- SourceOutputWithWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
-
Implementation of the SourceOutput.
- SourceOutputWithWatermarks(PushingAsyncDataInput.DataOutput<T>, WatermarkOutput, WatermarkOutput, TimestampAssigner<T>, WatermarkGenerator<T>) - Constructor for class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and
watermarks to the (possibly different) WatermarkOutput.
- SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
-
- SourceStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- SourceTransformation<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - Class in org.apache.flink.streaming.api.transformations
-
- SourceTransformation(String, Source<OUT, SplitT, EnumChkT>, WatermarkStrategy<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Creates a new Transformation
with the given name, output type and parallelism.
- SourceTransformation(String, Source<OUT, SplitT, EnumChkT>, WatermarkStrategy<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- SourceTransformationTranslator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - Class in org.apache.flink.streaming.runtime.translators
-
- SourceTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
-
- StandardSinkTopologies - Class in org.apache.flink.streaming.api.connector.sink2
-
This utility class provides building blocks for custom topologies.
- start() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- startLatencyMeasurement() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Starts mailbox latency measurement.
- startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Starts a new task chain beginning at this operator.
- startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called whenever the traversal starts with a new key.
- startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
-
- startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
-
- startPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Starts emitting periodic watermarks, if this implementation produces watermarks, and if
periodic watermarks are configured.
- startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Starts the local
InternalTimerServiceImpl
by:
Setting the
keySerialized
and
namespaceSerializer
for the timers it
will contain.
- state - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- State() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- State(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>, List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>, Optional<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- stateBackend - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Our state backend.
- StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source
-
A stateful streaming source that emits each number from a given interval exactly once, possibly
in parallel.
- StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
Creates a source that emits all numbers from the given interval exactly once.
- stateKeySelector - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
-
KeySelector
for extracting a key from an element being processed.
- stateKeyType - Variable in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
-
- StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- StateSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- status - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- statusWatermarkValve - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
Valve that controls how watermarks and watermark statuses are forwarded.
- StatusWatermarkValve - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
A
StatusWatermarkValve
embodies the logic of how
Watermark
and
WatermarkStatus
are propagated to downstream outputs, given a set of one or multiple input
channels that continuously receive them.
- StatusWatermarkValve(int) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
Returns a new StatusWatermarkValve
.
- StatusWatermarkValve.InputChannelStatus - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
An InputChannelStatus
keeps track of an input channel's last watermark, stream
status, and whether or not the channel's current watermark is aligned with the overall
watermark output from the valve.
- STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- stop(StopMode) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
- stop() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
-
- stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
-
- stopPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Stops emitting periodic watermarks.
- Strategy(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
-
- Strategy(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
-
- StreamConfig - Class in org.apache.flink.streaming.api.graph
-
- StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
-
- StreamConfig.InputConfig - Interface in org.apache.flink.streaming.api.graph
-
Interface representing chained inputs.
- StreamConfig.InputRequirement - Enum in org.apache.flink.streaming.api.graph
-
Requirements of the different inputs of an operator.
- StreamConfig.NetworkInputConfig - Class in org.apache.flink.streaming.api.graph
-
- StreamConfig.SourceInputConfig - Class in org.apache.flink.streaming.api.graph
-
A serialized representation of an input.
- StreamEdge - Class in org.apache.flink.streaming.api.graph
-
An edge in the streaming topology.
- StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamEdge(StreamNode, StreamNode, int, long, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
-
An element in a data stream.
- StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
- StreamElementQueue<OUT> - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- StreamElementSerializer.StreamElementSerializerSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamElementSerializerSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
-
- StreamExchangeMode - Enum in org.apache.flink.streaming.api.transformations
-
The data exchange mode between operators during
StreamGraph
generation.
- StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
-
The StreamExecutionEnvironment is the context in which a streaming program is executed.
- StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironment(Configuration, ClassLoader) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - 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(ExecutionConfig, CheckpointConfig, SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
-
- StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
A generator that generates a
StreamGraph
from a graph of
Transformation
s.
- StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig, ReadableConfig) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
-
Interface for different implementations of generating hashes over a stream graph.
- StreamGraphHasherV2 - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher from Flink 1.2.
- StreamGraphHasherV2() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- StreamGraphUserHashHasher - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher that works with user provided hashes.
- StreamGraphUserHashHasher() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- StreamGraphUtils - Class in org.apache.flink.streaming.util.graph
-
Utility class that contains helper methods to generating
StreamGraph
.
- StreamGraphUtils() - Constructor for class org.apache.flink.streaming.util.graph.StreamGraphUtils
-
- StreamGroupedReduceOperator<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedReduceOperator(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
-
- StreamingFileSink<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
- StreamingFileSink(StreamingFileSink.BucketsBuilder<IN, ?, ? extends StreamingFileSink.BucketsBuilder<IN, ?, ?>>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
-
Deprecated.
Creates a new StreamingFileSink
that writes files to the given base directory with
the give buckets properties.
- StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Deprecated.
- StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Deprecated.
A builder for configuring the sink for bulk-encoding formats, e.g.
- StreamingFileSink.DefaultBulkFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Deprecated.
- StreamingFileSink.DefaultRowFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Deprecated.
- StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Deprecated.
A builder for configuring the sink for row-wise encoding formats.
- StreamingFileSinkHelper<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
- StreamingFileSinkHelper(Buckets<IN, ?>, boolean, OperatorStateStore, ProcessingTimeService, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
-
- StreamingFunctionUtils - Class in org.apache.flink.streaming.util.functions
-
Utility class that contains helper methods to work with Flink Streaming Functions
.
- StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
The StreamingJobGraphGenerator converts a
StreamGraph
into a
JobGraph
.
- StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
-
Implementation of the RuntimeContext
, for streaming
operators.
- StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- StreamingRuntimeContext(Environment, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, OperatorID, ProcessingTimeService, KeyedStateStore, ExternalResourceInfoProvider) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- StreamInputProcessor - Interface in org.apache.flink.streaming.runtime.io
-
- StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTask
that is used for executing feedback edges.
- StreamIterationHead(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTask
that is used for executing feedback edges.
- StreamIterationTail(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
-
- StreamMultipleInputProcessor - Class in org.apache.flink.streaming.runtime.io
-
- StreamMultipleInputProcessor(MultipleInputSelectionHandler, StreamOneInputProcessor<?>[]) - Constructor for class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
-
- StreamMultipleInputProcessorFactory - Class in org.apache.flink.streaming.runtime.io
-
- StreamMultipleInputProcessorFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
-
- StreamNode - Class in org.apache.flink.streaming.api.graph
-
Class representing the operators in the streaming programs, with all their properties.
- StreamNode(Integer, String, String, StreamOperator<?>, String, Class<? extends TaskInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
-
- StreamNode(Integer, String, String, StreamOperatorFactory<?>, String, Class<? extends TaskInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
-
- StreamOneInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
-
- StreamOneInputProcessor(StreamTaskInput<IN>, PushingAsyncDataInput.DataOutput<IN>, BoundedMultiInput) - Constructor for class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
-
- StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Basic interface for stream operators.
- StreamOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
- StreamOperatorFactoryUtil - Class in org.apache.flink.streaming.api.operators
-
A utility to instantiate new operators with a given factory.
- StreamOperatorFactoryUtil() - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
-
- StreamOperatorParameters<OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamOperatorParameters(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>, Supplier<ProcessingTimeService>, OperatorEventDispatcher) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorParameters
-
- StreamOperatorStateContext - Interface in org.apache.flink.streaming.api.operators
-
This interface represents a context from which a stream operator can initialize everything
connected to state such as e.g.
- streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - Method in interface org.apache.flink.streaming.api.operators.StreamTaskStateInitializer
-
- streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- StreamOperatorStateHandler - Class in org.apache.flink.streaming.api.operators
-
Class encapsulating various state backend handling logic for
StreamOperator
implementations.
- StreamOperatorStateHandler(StreamOperatorStateContext, ExecutionConfig, CloseableRegistry) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
- StreamOperatorStateHandler.CheckpointedStreamOperator - Interface in org.apache.flink.streaming.api.operators
-
- StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
This class handles the finish, endInput and other related logic of a
StreamOperator
.
- streamOutputs - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
A special ChannelSelector
for use in streaming programs.
- StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- StreamPipelineOptions - Class in org.apache.flink.streaming.api.environment
-
The configuration options
for job execution.
- StreamPipelineOptions() - Constructor for class org.apache.flink.streaming.api.environment.StreamPipelineOptions
-
- StreamProject<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.streaming.api.operators
-
- StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
-
- StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
-
- StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
-
- StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
One value in a data stream.
- StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord.
- StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord wrapping the given value.
- StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
-
- 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, boolean) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
- StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
- StreamSourceContexts - Class in org.apache.flink.streaming.api.operators
-
Source contexts for various stream time characteristics.
- StreamSourceContexts() - Constructor for class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
Base class for all streaming tasks.
- StreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor, TaskMailbox) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- StreamTask.CanEmitBatchOfRecordsChecker - Interface in org.apache.flink.streaming.runtime.tasks
-
Check whether records can be emitted in batch.
- StreamTaskActionExecutor - Interface in org.apache.flink.streaming.runtime.tasks
-
- StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor - Class in org.apache.flink.streaming.runtime.tasks
-
- 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.
- StreamTaskExternallyInducedSourceInput<T> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTaskExternallyInducedSourceInput(SourceOperator<T, ?>, Consumer<Long>, int, int) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
-
- StreamTaskFinishedOnRestoreSourceInput<T> - Class in org.apache.flink.streaming.runtime.tasks
-
A special source input implementation that immediately emit END_OF_INPUT.
- StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T, ?>, int, int) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
-
- StreamTaskInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
Basic interface for inputs of stream operators.
- StreamTaskNetworkInput<T> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
-
- StreamTaskNetworkInputFactory - Class in org.apache.flink.streaming.runtime.io
-
- StreamTaskNetworkInputFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
-
- StreamTaskSourceInput<T> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTaskSourceInput(SourceOperator<T, ?>, int, int) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
- StreamTaskStateInitializer - Interface in org.apache.flink.streaming.api.operators
-
- StreamTaskStateInitializerImpl - Class in org.apache.flink.streaming.api.operators
-
- StreamTaskStateInitializerImpl(Environment, StateBackend) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- StreamTaskStateInitializerImpl(Environment, StateBackend, TtlTimeProvider, InternalTimeServiceManager.Provider) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- StreamTwoInputProcessorFactory - Class in org.apache.flink.streaming.runtime.io
-
- StreamTwoInputProcessorFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
-
- stringGenerator(int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
-
- stringGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- SubtaskCheckpointCoordinator - Interface in org.apache.flink.streaming.runtime.tasks
-
Coordinates checkpointing-related work for a subtask (i.e.
- subtaskReset(int, long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
-
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the data stream at the given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at the given field for
every window.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives a rolling sum of the data stream at the given position
grouped by the given key.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current sum of the data stream at the given field by
the given key.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the data stream at the given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at the given field for
every window.
- SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
-
Internal function for summing up contents of fields.
- SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- supportsUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
-
- supportsUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- suspend() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
- suspendDefaultAction(PeriodTimer) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
Calling this method signals that the mailbox-thread should (temporarily) stop invoking
the default action, e.g.
- suspendDefaultAction() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
- suspendDefaultAction(PeriodTimer) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
-
- suspendDefaultAction() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
-
- synchronizedExecutor() - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
Returns an ExecutionDecorator that synchronizes each invocation.
- synchronizedExecutor(Object) - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
Returns an ExecutionDecorator that synchronizes each invocation on a given object.
- SynchronizedStreamTaskActionExecutor(Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- systemTimerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- tailOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- take(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
This method returns the oldest mail from the mailbox (head of queue) or blocks until a mail
is available.
- take(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- TaskMailbox - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
A task mailbox provides read and write access to a mailbox and has a lifecycle of open ->
(quiesced) -> closed.
- TaskMailbox.MailboxClosedException - Exception in org.apache.flink.streaming.runtime.tasks.mailbox
-
- TaskMailbox.State - Enum in org.apache.flink.streaming.runtime.tasks.mailbox
-
This enum represents the states of the mailbox lifecycle.
- TaskMailboxImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of
TaskMailbox
in a
BlockingQueue
fashion and
tailored towards our use case with multiple writers and single reader.
- TaskMailboxImpl(Thread) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- TaskMailboxImpl() - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- TestProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- TestProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- Time - Class in org.apache.flink.streaming.api.windowing.time
-
The definition of a time interval for windowing.
- TIME_CHARACTERISTIC - Static variable in class org.apache.flink.streaming.api.environment.StreamPipelineOptions
-
- TimeCharacteristic - Enum in org.apache.flink.streaming.api
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
-
- TimeDomain - Enum in org.apache.flink.streaming.api
-
TimeDomain
specifies whether a firing timer is based on event time or processing time.
- TimeEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps elements for a certain amount of time.
- TimeEvictor(long) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- TimeEvictor(long, boolean) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- timeout(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
- Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- TIMER_COMPARATOR - Static variable in interface org.apache.flink.streaming.api.operators.InternalTimer
-
- TimerException - Exception in org.apache.flink.streaming.runtime.tasks
-
RuntimeException
for wrapping exceptions that are thrown in the timer callback of the
timer service in
StreamTask
.
- TimerException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- TimerHeapInternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
-
Implementation of
InternalTimer
to use with a
HeapPriorityQueueSet
.
- TimerHeapInternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
A serializer for
TimerHeapInternalTimer
objects that produces a serialization format that
is lexicographically aligned the priority of the timers.
- TimerSerializer(TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializer
-
- TimerSerializerSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
-
- TimerSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
-
- TimerSerializerSnapshot(TimerSerializer<K, N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
- TimerService - Interface in org.apache.flink.streaming.api
-
Interface for working with time and timers.
- timerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The internal
TimerService
used to define the current processing time (default =
System.currentTimeMillis()
) and register timers for tasks to be executed in the
future.
- TimerService - Interface in org.apache.flink.streaming.runtime.tasks
-
A common timer service interface with life cycle methods.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the timestamp of the current input record or null
if the element does not
have an assigned timestamp.
- timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
-
- TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
-
Wrapper around an
Output
for user functions that expect a
Output
.
- TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
This is given to the InternalWindowFunction
for emitting elements with a given
timestamp.
- TimestampedFileInputSplit - Class in org.apache.flink.streaming.api.functions.source
-
- TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Creates a
TimestampedFileInputSplit
based on the file modification time and the rest
of the information of the
FileInputSplit
, as returned by the underlying filesystem.
- TimestampedInputSplit - Interface in org.apache.flink.streaming.api.functions.source
-
An extended InputSplit
that also includes information about:
The modification time of the file this split belongs to.
- TimestampedValue<T> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Stores the value and the timestamp of the record.
- TimestampedValue(T) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue.
- TimestampedValue(T, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue wrapping the given value.
- TimestampsAndWatermarks<T> - Interface in org.apache.flink.streaming.api.operators.source
-
Basic interface for the timestamp extraction and watermark generation logic for the SourceReader
.
- TimestampsAndWatermarks.WatermarkUpdateListener - Interface in org.apache.flink.streaming.api.operators.source
-
Lets the owner/creator of the output know about latest emitted watermark.
- TimestampsAndWatermarksContext - Class in org.apache.flink.streaming.api.operators.source
-
A simple implementation of a context that is both TimestampAssignerSupplier.Context
and
WatermarkGeneratorSupplier.Context
.
- TimestampsAndWatermarksContext(MetricGroup) - Constructor for class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
-
- TimestampsAndWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that may do one or both of the following: extract timestamps from events and
generate watermarks.
- TimestampsAndWatermarksOperator(WatermarkStrategy<T>, boolean) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
- TimestampsAndWatermarksOperator.WatermarkEmitter - Class in org.apache.flink.streaming.runtime.operators
-
Implementation of the WatermarkEmitter
, based on the components that are available
inside a stream operator.
- TimestampsAndWatermarksTransformation<IN> - Class in org.apache.flink.streaming.api.transformations
-
- TimestampsAndWatermarksTransformation(String, int, Transformation<IN>, WatermarkStrategy<IN>, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Creates a new Transformation
with the given name, output type and parallelism.
- TimestampsAndWatermarksTransformationTranslator<IN> - Class in org.apache.flink.streaming.runtime.translators
-
- TimestampsAndWatermarksTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
-
- timeWindow(Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
A
Window
that represents a time interval from
start
(inclusive) to
end
(exclusive).
- TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
The serializer used to write the TimeWindow type.
- TimeWindow.Serializer.TimeWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
-
Serializer configuration snapshot for compatibility and format evolution.
- timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- TimeWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer.TimeWindowSerializerSnapshot
-
- toConfiguration() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- TOLERABLE_FAILURE_NUMBER - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
-
- toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Converts the time interval to milliseconds.
- toString() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
- toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSink
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
-
- toString() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- toString() - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
- toString() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
-
- toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
- 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.checkpointing.CheckpointedInputGate
-
- toString() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- toString() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- TransactionHolder(TXN, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
-
- transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- transform(String, TypeInformation<R>, TwoInputStreamOperatorFactory<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators along with the type information that will transform
the DataStream.
- transform(String, TypeInformation<R>, OneInputStreamOperatorFactory<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators created by the given factory along with the type
information that will transform the DataStream.
- transform(AbstractMultipleInputTransformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
-
- transform(Transformation<?>) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Transforms the transformation and updates the current stream graph.
- transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
-
- transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- TransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - Interface in org.apache.flink.streaming.api.graph
-
A TransformationTranslator
is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode.
- TransformationTranslator.Context - Interface in org.apache.flink.streaming.api.graph
-
A context giving the necessary information for the translation of a given transformation.
- translateForBatch(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
- translateForBatch(T, TransformationTranslator.Context) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator
-
Translates a given Transformation
to its runtime implementation for BATCH-style
execution.
- translateForBatch(SinkTransformation<Input, Output>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
-
- translateForBatchInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
Translates a given Transformation
to its runtime implementation for BATCH-style
execution.
- translateForBatchInternal(BroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
-
- translateForBatchInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
-
- translateForBatchInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
-
- translateForBatchInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
-
- translateForBatchInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
-
- translateForBatchInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
-
- translateForBatchInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
-
- translateForBatchInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
-
- translateForBatchInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
-
- translateForBatchInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
-
- translateForBatchInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
-
- translateForBatchInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
-
- translateForBatchInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
-
- translateForBatchInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
-
- translateForStreaming(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
- translateForStreaming(T, TransformationTranslator.Context) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator
-
Translates a given Transformation
to its runtime implementation for STREAMING-style
execution.
- translateForStreaming(SinkTransformation<Input, Output>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
-
- translateForStreamingInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
Translates a given Transformation
to its runtime implementation for STREAMING-style
execution.
- translateForStreamingInternal(BroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
-
- translateForStreamingInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
-
- translateForStreamingInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
-
- translateForStreamingInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
-
- translateForStreamingInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
-
- translateForStreamingInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
-
- translateForStreamingInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
-
- translateForStreamingInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
-
- translateForStreamingInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
-
- translateForStreamingInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
-
- translateForStreamingInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
-
- translateForStreamingInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
-
- translateForStreamingInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
-
- translateForStreamingInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
-
- translateInternal(Transformation<OUT>, Transformation<IN1>, Transformation<IN2>, StreamOperatorFactory<OUT>, TypeInformation<?>, KeySelector<IN1, ?>, KeySelector<IN2, ?>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
-
- traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Performs a traversal about logical the multi-map that results from the union of the given
maps.
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in interface org.apache.flink.streaming.api.graph.StreamGraphHasher
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- Trigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A Trigger
determines when a pane of a window should be evaluated to emit the results for
that part of the window.
- Trigger() - Constructor for class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- Trigger.OnMergeContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
- Trigger.TriggerContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
A context object that is given to
Trigger
methods to allow them to register timer
callbacks and deal with state.
- TRIGGER_THREAD_GROUP - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The thread group that holds all trigger timer threads.
- Triggerable<K,N> - Interface in org.apache.flink.streaming.api.operators
-
- triggerCheckpoint(long) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
-
Triggers a checkpoint.
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
-
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
-
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- triggerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
-
Result type for trigger methods.
- triggerSerializationAndReturnFuture(Executor) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Trigger the object config serialization and return the completable future.
- tryCancel(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
-
- tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- tryPut(StreamElement) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Tries to put the given element in the queue.
- tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- tryTake(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns an optional with either the oldest mail from the mailbox (head of queue) if the
mailbox is not empty or an empty optional otherwise.
- tryTake(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- tryTakeFromBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns an optional with either the oldest mail from the batch (head of queue) if the batch
is not empty or an empty optional otherwise.
- tryTakeFromBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
-
- tryYield() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
-
- TumblingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the timestamp of the
elements.
- TumblingEventTimeWindows(long, long, WindowStagger) - 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.
- tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with two inputs.
- TwoInputStreamOperatorFactory<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
- TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- TwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
- TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new TwoInputTransformation
from the given inputs and operator.
- TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new TwoInputTransformation
from the given inputs and operator.
- TwoInputTransformationTranslator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.translators
-
- TwoInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
-
- TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
This is a recommended base class for all of the
SinkFunction
that intend to implement
exactly-once semantic.
- TwoPhaseCommitSinkFunction(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Use default ListStateDescriptor
for internal state serialization.
- TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
- TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
Custom TypeSerializer
for the sink state.
- TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
- TwoPhaseCommitSinkFunction.TransactionHolder<TXN> - Class in org.apache.flink.streaming.api.functions.sink
-
Adds metadata (currently only the start time of the transaction) to the transaction object.
- TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
- TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
Deprecated.
Creates a new de-/serialization schema for the given type.
- validateTransformationUid(StreamGraph, Transformation<?>) - Static method in class org.apache.flink.streaming.util.graph.StreamGraphUtils
-
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.io.DataInputStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- values() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Returns the collection of
StreamElement
currently contained in this queue for
checkpointing.
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- values() - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.io.DataInputStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesToEmit - Variable in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
- VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- waitForPendingCheckpoints() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Waits for all the pending checkpoints to finish their asynchronous step.
- Watermark - Class in org.apache.flink.streaming.api.watermark
-
A Watermark tells operators that no elements with a timestamp older or equal to the watermark
timestamp should arrive at the operator.
- Watermark(long) - Constructor for class org.apache.flink.streaming.api.watermark.Watermark
-
Creates a new watermark with the given timestamp in milliseconds.
- watermark - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- WatermarkEmitter(Output<?>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
-
- WatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
-
A Gauge
for exposing the current input/output watermark.
- WatermarkGauge() - Constructor for class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
-
- WatermarkGaugeExposingOutput<T> - Interface in org.apache.flink.streaming.runtime.tasks
-
- watermarkStatus - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
-
- WatermarkStatus - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
A Watermark Status element informs stream tasks whether or not they should continue to expect
watermarks from the input stream that sent them.
- WatermarkStatus(int) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
-
- WatermarkToDataOutput - Class in org.apache.flink.streaming.api.operators.source
-
An adapter that exposes a WatermarkOutput
based on a PushingAsyncDataInput.DataOutput
.
- WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>) - Constructor for class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
- WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>, TimestampsAndWatermarks.WatermarkUpdateListener) - Constructor for class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
Creates a new WatermarkOutput against the given DataOutput.
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a KeySelector
for elements from the first input.
- where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a KeySelector
for elements from the first input with explicit type
information.
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a KeySelector
for elements from the first input.
- where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a KeySelector
for elements from the first input with explicit type
information for the key type.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where.EqualTo
-
Specifies the window on which the co-group operation works.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
-
Specifies the window on which the join operation works.
- window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this data stream to a WindowedStream
, which evaluates windows over a key
grouped stream.
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
-
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the window that is being evaluated.
- Window - Class in org.apache.flink.streaming.api.windowing.windows
-
A Window
is a grouping of elements into finite buckets.
- Window() - Constructor for class org.apache.flink.streaming.api.windowing.windows.Window
-
- window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
-
- window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this data stream to a AllWindowedStream
, which evaluates windows over a non
key grouped stream.
- WindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
assigns zero or more
Windows
to an element.
- WindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
- windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- WindowAssigner.WindowAssignerContext - Class in org.apache.flink.streaming.api.windowing.assigners
-
A context provided to the
WindowAssigner
that allows it to query the current
processing time.
- WindowAssignerContext() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
- windowAssignerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- WindowContext(W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
WindowedStream
represents a data stream where elements are grouped by key, and for each
key, the stream of elements is split into windows based on a
WindowAssigner
.
- WindowedStream(KeyedStream<T, K>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.WindowedStream
-
- WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over keyed (grouped) windows.
- WindowOperator<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Creates a new WindowOperator
based on the given policies and user functions.
- WindowOperator.AbstractPerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Base class for per-window KeyedStateStores
.
- WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Context
is a utility for handling Trigger
invocations.
- WindowOperator.MergingWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperator.PerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Internal class for keeping track of in-flight timers.
- WindowOperator.WindowContext - Class in org.apache.flink.streaming.runtime.operators.windowing
-
A utility class for handling ProcessWindowFunction
invocations.
- WindowOperatorBuilder<T,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperatorBuilder(WindowAssigner<? super T, W>, Trigger<? super T, ? super W>, ExecutionConfig, TypeInformation<T>, KeySelector<T, K>, TypeInformation<K>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
-
- windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
For serializing the window in checkpoints.
- WindowStagger - Enum in org.apache.flink.streaming.api.windowing.assigners
-
A WindowStagger
staggers offset in runtime for each window assignment.
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
-
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
State accessor for per-key and per-window state.
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
State accessor for per-key and per-window state.
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
-
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- windowState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- windowState - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- with(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- with(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- with(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- WithBoundedness - Interface in org.apache.flink.streaming.api.transformations
-
An interface to be implemented by transformations that have explicitly set Boundedness
.
- withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- withFeedbackType(Class<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(TypeHint<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(TypeInformation<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams
.
- withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions
based on the element timestamp.
- WithMasterCheckpointHook<E> - Interface in org.apache.flink.streaming.api.checkpoint
-
This interface can be implemented by streaming functions that need to trigger a "global action"
on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
- withNewBucketAssigner(BucketAssigner<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withNewBucketAssignerAndPolicy(BucketAssigner<IN, ID>, RollingPolicy<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- WithPostCommitTopology<InputT,CommT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology after Committer
.
- WithPreCommitTopology<InputT,CommT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology after SinkWriter
and before Committer
.
- WithPreWriteTopology<InputT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology before SinkWriter
.
- withRollingPolicy(CheckpointRollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withRollingPolicy(RollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
Sets the handler for violations to the ascending timestamp order.
- WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Time) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Time) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- wrap(Sink<InputT, ?, ?, ?>) - Static method in class org.apache.flink.streaming.api.transformations.SinkV1Adapter
-
- wrapInputs(TaskInvokable, StreamTaskInput<Object>[], KeySelector<Object, K>[], TypeSerializer<Object>[], TypeSerializer<K>, StreamTaskInput<Object>[], MemoryManager, IOManager, boolean, double, Configuration, ExecutionConfig) - Static method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
-
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
Deprecated.
Writes the contents of tupleList to the file specified by path.
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
Deprecated.
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
Deprecated.
- write(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- writeAsCsv(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- writeAsText(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- WriteFormat<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- WriteFormat() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
Deprecated.
- WriteFormatAsCsv<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- WriteFormatAsCsv() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
Deprecated.
- WriteFormatAsText<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- WriteFormatAsText() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
Deprecated.
- writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
- WriteSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- WriteSinkFunction(String, WriteFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- WriteSinkFunctionByMillis<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
Deprecated.
- writeTimersSnapshot(DataOutputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter
-
Writes the timers snapshot to the output view.
- writeToSocket(String, int, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the DataStream to a socket as a byte array.
- writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- writeWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
Writes the given watermark to the sink.