跳过导航链接
A B C D E F G H I J K L M N O P Q R S T U V W Y 

A

abort(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction.
abortCheckpoint(long, CheckpointException) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
abortCheckpoint(long, CheckpointException) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
abortCheckpointOnBarrier(long, CheckpointException) - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
abortCheckpointOnBarrier(long, CheckpointException) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
abortCheckpointOnBarrier(long, CheckpointException, OperatorChain<?, ?>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
AbstractBroadcastStateTransformation<IN1,IN2,OUT> - org.apache.flink.streaming.api.transformations中的类
Base class for Broadcast State transformations.
AbstractBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
AbstractCollectResultBuffer<T> - org.apache.flink.streaming.api.operators.collect中的类
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction.
AbstractCollectResultBuffer(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
AbstractDeserializationSchema<T> - org.apache.flink.streaming.util.serialization中的类
已过时。
Use AbstractDeserializationSchema instead.
AbstractDeserializationSchema() - 类 的构造器org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
已过时。
 
AbstractInput<IN,OUT> - org.apache.flink.streaming.api.operators中的类
Base abstract implementation of Input interface intended to be used when extending AbstractStreamOperatorV2.
AbstractInput(AbstractStreamOperatorV2<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.operators.AbstractInput
 
AbstractMultipleInputTransformation<OUT> - org.apache.flink.streaming.api.transformations中的类
Base class for transformations representing the application of a MultipleInputStreamOperator to input Transformations.
AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
AbstractPerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
AbstractStreamOperator<OUT> - org.apache.flink.streaming.api.operators中的类
Base class for all stream operators.
AbstractStreamOperator() - 类 的构造器org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
AbstractStreamOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的类
Base class for all stream operator factories.
AbstractStreamOperatorFactory() - 类 的构造器org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
AbstractStreamOperatorV2<OUT> - org.apache.flink.streaming.api.operators中的类
New base class for all stream operators, intended to eventually replace AbstractStreamOperator.
AbstractStreamOperatorV2(StreamOperatorParameters<OUT>, int) - 类 的构造器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>>> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
AbstractTwoInputStreamTask<IN1,IN2,OUT> - org.apache.flink.streaming.runtime.tasks中的类
Abstract class for executing a TwoInputStreamOperator.
AbstractTwoInputStreamTask(Environment) - 类 的构造器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>> - org.apache.flink.streaming.runtime.translators中的类
A base class with functionality used during translating transformations with two inputs.
AbstractTwoInputTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
 
AbstractUdfStreamOperator<OUT,F extends org.apache.flink.api.common.functions.Function> - org.apache.flink.streaming.api.operators中的类
This is used as the base class for operators that have a user-defined function.
AbstractUdfStreamOperator(F) - 类 的构造器org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
accumulateFinalResults() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
acknowledgeIDs(long, Set<UId>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Acknowledges the session ids.
acknowledgeSessionIDs(List<SessionId>) - 类 中的方法org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Acknowledges the session ids.
ACTIVE - 类 中的静态变量org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
ACTIVE_STATUS - 类 中的静态变量org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
add(Object, Object) - 类 中的方法org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
add(Extractor<TO, OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
add(T) - 类 中的方法org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
addAll(List<T>) - 类 中的方法org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
addCoOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addDefaultKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addEdge(Integer, Integer, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addEdge(Integer, Integer, int, IntermediateDataSetID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addFeedbackEdge(Transformation<F>) - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Adds a feedback edge.
addFeedbackEdge(Transformation<T>) - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Adds a feedback edge.
addGlobalCommitter(DataStream<CommittableMessage<CommT>>, SerializableSupplier<Committer<CommT>>, SerializableSupplier<SimpleVersionedSerializer<CommT>>) - 类 中的静态方法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) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Adds an ID to be stored with the current checkpoint.
addInEdge(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
addInput(Transformation<?>, KeySelector<?, ?>) - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
addInput(Transformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.MultipleInputTransformation
 
addInputRequirement(int, StreamConfig.InputRequirement) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
addLegacySource(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addMessage(CommittableMessage<CommT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Adds a CommittableMessage to the collector to hold it until emission.
addMultipleInputOperator(Integer, String, String, StreamOperatorFactory<OUT>, List<TypeInformation<?>>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addNode(Integer, String, String, Class<? extends TaskInvokable>, StreamOperatorFactory<?>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addOperator(Transformation<?>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds an operator to the list of operators that should be executed when calling StreamExecutionEnvironment.execute().
addOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addOutEdge(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
addPostCommitTopology(DataStream<CommittableMessage<CommT>>) - 接口 中的方法org.apache.flink.streaming.api.connector.sink2.WithPostCommitTopology
Adds a custom post-commit topology where all committables can be processed.
addPreCommitTopology(DataStream<CommittableMessage<CommT>>) - 接口 中的方法org.apache.flink.streaming.api.connector.sink2.WithPreCommitTopology
Intercepts and modifies the committables sent on checkpoint or at end of input.
addPreWriteTopology(DataStream<InputT>) - 接口 中的方法org.apache.flink.streaming.api.connector.sink2.WithPreWriteTopology
Adds an arbitrary topology before the writer.
addProcessedBytes(int) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
addSink(SinkFunction<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Adds the given sink to this DataStream.
addSink(SinkFunction<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
 
addSink(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addSource(SourceFunction<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a Data Source to the streaming topology.
addSource(SourceFunction<OUT>, String) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>, StreamExchangeMode) - 类 中的方法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) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Adds a new Window to the set of in-flight windows.
advance(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
advanceToEndOfEventTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
advanceToEndOfEventTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
advanceToEndOfEventTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
advanceToEndOfEventTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Emits the MAX_WATERMARK so that all registered timers are fired.
advanceWatermark(long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
advanceWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
Advances the Watermark of all managed timer services, potentially firing event time timers.
advanceWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 
advanceWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
 
afterInvoke() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
aggregate(AggregateFunction<T, ACC, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
 
aggregate(AggregateFunction<T, ACC, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - org.apache.flink.streaming.api.functions.windowing中的类
A AllWindowFunction that composes an AggregateFunction and AllWindowFunction.
AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - org.apache.flink.streaming.api.functions.windowing中的类
A WindowFunction that composes an AggregateFunction and WindowFunction.
AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
AggregationFunction<T> - org.apache.flink.streaming.api.functions.aggregation中的类
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunction() - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
 
AggregationFunction.AggregationType - 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...) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
ALIGNED_CHECKPOINT_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
alignedBarrierTimeout(long) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
alignedBarrierTimeout(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
ALIGNMENT_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
ALL - 类 中的静态变量org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select all inputs.
allActionsCompleted() - 接口 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
allChannelsRecovered() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
allChannelsRecovered() - 接口 中的方法org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
 
allowedLateness(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
The allowed lateness for elements.
allowedLateness(Time) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
AllWindowedStream<T,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.api.datastream.AllWindowedStream
 
AllWindowFunction<IN,OUT,W extends Window> - 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...) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
anyOf(int, CompletableFuture<?>) - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
Combine availabilityFuture using anyOf logic with other previously registered futures.
apply(AllWindowFunction<T, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(CoGroupFunction<T1, T2, T>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
apply(W, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
apply(W, Iterable<IN>, Collector<OUT>) - 接口 中的方法org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
Evaluates the window and outputs none or several elements.
apply(W, Iterable<T>, Collector<T>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<T>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
apply(W, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - 接口 中的方法org.apache.flink.streaming.api.functions.windowing.WindowFunction
Evaluates the window and outputs none or several elements.
apply(WindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
applyToKeyedState(StateDescriptor<S, VS>, KeyedStateFunction<KS, S>) - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
Applies the provided function to the state associated with the provided state descriptor.
areAllDataInputsFinished() - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
areAllInputsFinished() - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
areAllInputsSelected() - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
Tests if all inputs are selected.
areExplicitEnvironmentsAllowed() - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.
ArrayFromTuple - org.apache.flink.streaming.api.functions.windowing.delta.extractor中的类
Converts a Tuple to an Object-Array.
ArrayFromTuple() - 类 的构造器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...) - 类 的构造器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) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
AscendingTimestampExtractor<T> - org.apache.flink.streaming.api.functions中的类
已过时。
AscendingTimestampExtractor() - 类 的构造器org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
已过时。
 
AscendingTimestampExtractor<T> - org.apache.flink.streaming.api.functions.timestamps中的类
已过时。
AscendingTimestampExtractor() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
已过时。
 
AscendingTimestampExtractor.FailingHandler - org.apache.flink.streaming.api.functions.timestamps中的类
已过时。
Handler that fails the program when timestamp monotony is violated.
AscendingTimestampExtractor.IgnoringHandler - org.apache.flink.streaming.api.functions.timestamps中的类
已过时。
Handler that does nothing when timestamp monotony is violated.
AscendingTimestampExtractor.LoggingHandler - org.apache.flink.streaming.api.functions.timestamps中的类
已过时。
Handler that only logs violations of timestamp monotony, on WARN log level.
AscendingTimestampExtractor.MonotonyViolationHandler - org.apache.flink.streaming.api.functions.timestamps中的接口
已过时。
Interface for handlers that handle violations of the monotonous ascending timestamps property.
asLatencyMarker() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a LatencyMarker.
asQueryableState(String) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as queryable ValueState instance.
asQueryableState(String, ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ValueState instance.
asQueryableState(String, ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ReducingState instance.
asRecord() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamRecord.
AssignerWithPeriodicWatermarks<T> - org.apache.flink.streaming.api.functions中的接口
已过时。
AssignerWithPeriodicWatermarksAdapter<T> - org.apache.flink.streaming.runtime.operators.util中的类
An adapter that wraps a AssignerWithPeriodicWatermarks into a WatermarkGenerator.
AssignerWithPeriodicWatermarksAdapter(AssignerWithPeriodicWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
AssignerWithPeriodicWatermarksAdapter.Strategy<T> - org.apache.flink.streaming.runtime.operators.util中的类
A WatermarkStrategy that returns an AssignerWithPeriodicWatermarks wrapped as a WatermarkGenerator.
AssignerWithPunctuatedWatermarks<T> - org.apache.flink.streaming.api.functions中的接口
已过时。
AssignerWithPunctuatedWatermarksAdapter<T> - org.apache.flink.streaming.runtime.operators.util中的类
An adapter that wraps a AssignerWithPunctuatedWatermarks into a WatermarkGenerator.
AssignerWithPunctuatedWatermarksAdapter(AssignerWithPunctuatedWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
AssignerWithPunctuatedWatermarksAdapter.Strategy<T> - org.apache.flink.streaming.runtime.operators.util中的类
A WatermarkStrategy that returns an AssignerWithPunctuatedWatermarks wrapped as a WatermarkGenerator.
assignTimestampsAndWatermarks(WatermarkStrategy<T>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a Collection of windows that should be assigned to the element.
asSpecializedSink() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter
 
asWatermark() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
asWatermarkStatus() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a WatermarkStatus.
AsyncDataOutputToOutput(Output<StreamRecord<T>>, InternalSourceReaderMetricGroup, WatermarkGauge) - 类 的构造器org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
 
AsyncDataStream - org.apache.flink.streaming.api.datastream中的类
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream() - 类 的构造器org.apache.flink.streaming.api.datastream.AsyncDataStream
 
AsyncDataStream.OutputMode - org.apache.flink.streaming.api.datastream中的枚举
Output mode for asynchronous operations.
AsyncFunction<IN,OUT> - org.apache.flink.streaming.api.functions.async中的接口
A function to trigger Async I/O operation.
asyncInvoke(IN, ResultFuture<OUT>) - 接口 中的方法org.apache.flink.streaming.api.functions.async.AsyncFunction
Trigger async operation for each stream input.
asyncInvoke(IN, ResultFuture<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
AsyncRetryPredicate<OUT> - org.apache.flink.streaming.api.functions.async中的接口
Interface encapsulates an asynchronous retry predicate.
AsyncRetryStrategies - org.apache.flink.streaming.util.retryable中的类
Utility class to create concrete AsyncRetryStrategy.
AsyncRetryStrategies() - 类 的构造器org.apache.flink.streaming.util.retryable.AsyncRetryStrategies
 
AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy<OUT> - org.apache.flink.streaming.util.retryable中的类
ExponentialBackoffDelayRetryStrategy.
AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder<OUT> - org.apache.flink.streaming.util.retryable中的类
ExponentialBackoffDelayRetryStrategyBuilder for building a ExponentialBackoffDelayRetryStrategy.
AsyncRetryStrategies.FixedDelayRetryStrategy<OUT> - org.apache.flink.streaming.util.retryable中的类
FixedDelayRetryStrategy.
AsyncRetryStrategies.FixedDelayRetryStrategyBuilder<OUT> - org.apache.flink.streaming.util.retryable中的类
FixedDelayRetryStrategyBuilder for building a FixedDelayRetryStrategy.
AsyncRetryStrategy<OUT> - org.apache.flink.streaming.api.functions.async中的接口
Interface encapsulates an asynchronous retry strategy.
AsyncWaitOperator<IN,OUT> - org.apache.flink.streaming.api.operators.async中的类
The AsyncWaitOperator allows to asynchronously process incoming stream records.
AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>, ProcessingTimeService, MailboxExecutor) - 类 的构造器org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
AsyncWaitOperatorFactory<IN,OUT> - org.apache.flink.streaming.api.operators.async中的类
The factory of AsyncWaitOperator.
AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - 类 的构造器org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 

B

BackendRestorerProcedure<T extends Closeable & org.apache.flink.util.Disposable,S extends org.apache.flink.runtime.state.StateObject> - org.apache.flink.streaming.api.operators中的类
This class implements the logic that creates (and potentially restores) a state backend.
BackendRestorerProcedure(FunctionWithException<Collection<S>, T, Exception>, CloseableRegistry, String) - 类 的构造器org.apache.flink.streaming.api.operators.BackendRestorerProcedure
Creates a new backend restorer using the given backend supplier and the closeable registry.
BarrierAlignmentUtil - org.apache.flink.streaming.runtime.io.checkpointing中的类
Utility for barrier alignment.
BarrierAlignmentUtil() - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
 
BarrierAlignmentUtil.Cancellable - org.apache.flink.streaming.runtime.io.checkpointing中的接口
A handle to a delayed action which can be cancelled.
BarrierAlignmentUtil.DelayableTimer - org.apache.flink.streaming.runtime.io.checkpointing中的接口
It can register a task to be executed some time later.
BaseBroadcastProcessFunction - org.apache.flink.streaming.api.functions.co中的类
The base class containing the functionality available to all broadcast process function.
BaseBroadcastProcessFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction
 
BaseBroadcastProcessFunction.Context - org.apache.flink.streaming.api.functions.co中的类
A base context available to the broadcasted stream side of a BroadcastConnectedStream.
BaseBroadcastProcessFunction.ReadOnlyContext - org.apache.flink.streaming.api.functions.co中的类
A context available to the non-broadcasted stream side of a BroadcastConnectedStream.
BatchCoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
A TwoInputStreamOperator for executing KeyedBroadcastProcessFunctions in RuntimeExecutionMode.BATCH execution mode.
BatchCoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
 
BatchCoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
A TwoInputStreamOperator for executing BroadcastProcessFunctions in RuntimeExecutionMode.BATCH execution mode.
BatchCoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
 
BatchExecutionCheckpointStorage - org.apache.flink.streaming.api.operators.sorted.state中的类
A simple CheckpointStorage which is used in a BATCH style execution.
BatchExecutionCheckpointStorage() - 类 的构造器org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
 
BatchExecutionInternalTimeService<K,N> - org.apache.flink.streaming.api.operators.sorted.state中的类
An implementation of a InternalTimerService that manages timers with a single active key at a time.
BatchExecutionInternalTimeServiceManager<K> - org.apache.flink.streaming.api.operators.sorted.state中的类
An implementation of a InternalTimeServiceManager that manages timers with a single active key at a time.
BatchExecutionInternalTimeServiceManager(ProcessingTimeService) - 类 的构造器org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
 
BatchExecutionKeyedStateBackend<K> - org.apache.flink.streaming.api.operators.sorted.state中的类
A CheckpointableKeyedStateBackend which keeps values for a single key at a time.
BatchExecutionKeyedStateBackend(TypeSerializer<K>, KeyGroupRange, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
BatchExecutionStateBackend - org.apache.flink.streaming.api.operators.sorted.state中的类
A simple StateBackend which is used in a BATCH style execution.
BatchExecutionStateBackend() - 类 的构造器org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
 
BatchGroupedReduceOperator<IN,KEY> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing a ReduceFunction on a KeyedStream in a RuntimeExecutionMode.BATCH mode.
BatchGroupedReduceOperator(ReduceFunction<IN>, TypeSerializer<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
 
beginTransaction() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Method that starts a new transaction.
between(Time, Time) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
Specifies the time boundaries over which the join operation works, so that leftElement.timestamp + lowerBound <= rightElement.timestamp <= leftElement.timestamp + upperBound By default both the lower and the upper bound are inclusive.
bigDecimalGenerator(int, int, int, int) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
blockConsumption(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
BlockingQueueBroker - org.apache.flink.streaming.runtime.io中的类
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams.
blockUntil(CompletableFuture<?>) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
 
booleanGenerator() - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
BoundedMultiInput - org.apache.flink.streaming.api.operators中的接口
Interface for multi-input operators that need to be notified about the logical/semantical end of input.
BoundedOneInput - org.apache.flink.streaming.api.operators中的接口
Interface for one-input operators that need to be notified about the logical/semantical end of input.
BoundedOutOfOrdernessTimestampExtractor<T> - org.apache.flink.streaming.api.functions.timestamps中的类
This is a AssignerWithPeriodicWatermarks used to emit Watermarks that lag behind the element with the maximum timestamp (in event time) seen so far by a fixed amount of time, t_late.
BoundedOutOfOrdernessTimestampExtractor(Time) - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
broadcast() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcasted to every parallel instance of the next operation.
broadcast(MapStateDescriptor<?, ?>...) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcasted to every parallel instance of the next operation.
BroadcastConnectedStream<IN1,IN2> - org.apache.flink.streaming.api.datastream中的类
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream, with a BroadcastStream with broadcast state(s).
BroadcastConnectedStream(StreamExecutionEnvironment, DataStream<IN1>, BroadcastStream<IN2>, List<MapStateDescriptor<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
 
broadcastEvent(AbstractEvent, boolean) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
broadcastEvent(AbstractEvent) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastEvent(AbstractEvent, boolean) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
BroadcastPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that selects all the output channels.
BroadcastPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
BroadcastProcessFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的类
A function to be applied to a BroadcastConnectedStream that connects BroadcastStream, i.e.
BroadcastProcessFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
 
BroadcastProcessFunction.Context - org.apache.flink.streaming.api.functions.co中的类
A context available to the broadcast side of a BroadcastConnectedStream.
BroadcastProcessFunction.ReadOnlyContext - org.apache.flink.streaming.api.functions.co中的类
A context available to the non-keyed side of a BroadcastConnectedStream (if any).
BroadcastStateTransformation<IN1,IN2,OUT> - org.apache.flink.streaming.api.transformations中的类
BroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.BroadcastStateTransformation
 
BroadcastStateTransformationTranslator<IN1,IN2,OUT> - org.apache.flink.streaming.runtime.translators中的类
BroadcastStateTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
 
BroadcastStream<T> - org.apache.flink.streaming.api.datastream中的类
A BroadcastStream is a stream with broadcast state(s).
BroadcastStream(StreamExecutionEnvironment, DataStream<T>, MapStateDescriptor<?, ?>...) - 类 的构造器org.apache.flink.streaming.api.datastream.BroadcastStream
 
Bucket<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
A bucket is the directory organization of the output of the StreamingFileSink.
bucketCreated(Bucket<IN, BucketID>) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
Notifies a new bucket has been created.
BucketFactory<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
A factory able to create buckets for the StreamingFileSink.
bucketInactive(Bucket<IN, BucketID>) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
Notifies a bucket become inactive.
BucketLifeCycleListener<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
Listener about the status of Bucket.
Buckets<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
The manager of the different active buckets in the StreamingFileSink.
Buckets(Path, BucketAssigner<IN, BucketID>, BucketFactory<IN, BucketID>, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, int, OutputFileConfig) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
A constructor creating a new empty bucket manager.
BucketsBuilder() - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
已过时。
 
BufferEntry(T, boolean) - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
BufferEntrySerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
BufferEntrySerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
BufferSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
BufferSerializerConfigSnapshot(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
build() - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
Constructs the CustomSinkOperatorUidHashes with the given uid hashes.
build() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
Creates the actual sink.
build() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
Creates the actual sink.
build(int) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection.Builder
Build normalized mask, if all inputs were manually selected, inputMask will be normalized to -1.
build() - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection.Builder
 
build() - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
 
build() - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
 
builder() - 类 中的静态方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
Creates a builder to construct CustomSinkOperatorUidHashes.
Builder() - 类 的构造器org.apache.flink.streaming.api.operators.InputSelection.Builder
 
BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>, CheckpointRollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
byteGenerator(byte, byte) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
byteGenerator(byte, byte) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 

C

cache() - 类 中的方法org.apache.flink.streaming.api.datastream.SideOutputDataStream
Caches the intermediate result of the transformation.
cache() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Cache the intermediate result of the transformation.
CACHE_CONSUMER_OPERATOR_NAME - 类 中的静态变量org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
 
CACHE_PRODUCER_OPERATOR_NAME - 类 中的静态变量org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
 
CachedDataStream<T> - org.apache.flink.streaming.api.datastream中的类
CachedDataStream represents a DataStream whose intermediate result will be cached at the first time when it is computed.
CachedDataStream(StreamExecutionEnvironment, Transformation<T>) - 类 的构造器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 - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
CacheTransformation<T> - 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) - 类 的构造器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>> - org.apache.flink.streaming.runtime.translators中的类
CacheTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
 
CacheTransformationTranslator.IdentityStreamOperator<T> - org.apache.flink.streaming.runtime.translators中的类
The CacheTransformationTranslator.IdentityStreamOperator acts as a dummy source to consume cached intermediate dataset.
CacheTransformationTranslator.NoOpStreamOperator<T> - org.apache.flink.streaming.runtime.translators中的类
The CacheTransformationTranslator.NoOpStreamOperator acts as a dummy sink so that the upstream can produce the intermediate dataset to be cached.
call(Callable<R>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
call(Callable<R>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
已过时。
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
已过时。
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
cancel() - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction
Cancels the source.
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
cancel() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
cancel() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
cancel() - 接口 中的方法org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.Cancellable
 
cancel() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancel() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Cancel all resources.
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
canEqual(Object) - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
canMerge() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
canMerge() - 类 中的方法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) - 接口 中的方法org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
 
canRetry(int) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
 
canRetry(int) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
 
ChainedSource(WatermarkGaugeExposingOutput<StreamRecord<?>>, StreamTaskSourceInput<?>) - 类 的构造器org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
 
chainedSources - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
chainingStrategy - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
chainingStrategy - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
ChainingStrategy - org.apache.flink.streaming.api.operators中的枚举
Defines the chaining scheme for the operator.
checkAndGetNextWatermark(T, long) - 接口 中的方法org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
已过时。
Asks this implementation if it wants to emit a watermark.
checkCollection(Collection<OUT>, Class<OUT>) - 类 中的静态方法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 - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CheckpointBarrierHandler - org.apache.flink.streaming.runtime.io.checkpointing中的类
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
CheckpointBarrierHandler(CheckpointableTask, Clock, boolean) - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
CheckpointBarrierTracker - org.apache.flink.streaming.runtime.io.checkpointing中的类
The CheckpointBarrierTracker keeps track of what checkpoint barriers have been received from which input channels.
CheckpointBarrierTracker(int, CheckpointableTask, Clock, boolean) - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
checkpointCfg - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Settings that control the checkpointing behavior.
CheckpointCommittableManager<CommT> - org.apache.flink.streaming.runtime.operators.sink.committables中的接口
This interface adds checkpoint meta information to the committable.
CheckpointCommitter - 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() - 类 的构造器org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
CheckpointConfig - org.apache.flink.streaming.api.environment中的类
Configuration that captures all checkpointing related settings.
CheckpointConfig(CheckpointConfig) - 类 的构造器org.apache.flink.streaming.api.environment.CheckpointConfig
Creates a deep copy of the provided CheckpointConfig.
CheckpointConfig() - 类 的构造器org.apache.flink.streaming.api.environment.CheckpointConfig
 
CheckpointConfig.ExternalizedCheckpointCleanup - org.apache.flink.streaming.api.environment中的枚举
Cleanup behaviour for externalized checkpoints when the job is cancelled.
checkpointCoordinator(long, CompletableFuture<byte[]>) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
CheckpointedCollectResultBuffer<T> - org.apache.flink.streaming.api.operators.collect中的类
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction.
CheckpointedCollectResultBuffer(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
 
CheckpointedFunction - 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 - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
CheckpointedInputGate - org.apache.flink.streaming.runtime.io.checkpointing中的类
The CheckpointedInputGate uses CheckpointBarrierHandler to handle incoming CheckpointBarrier from the InputGate.
CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor) - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
Creates a new checkpoint stream aligner.
CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor, UpstreamRecoveryTracker) - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
CHECKPOINTING_INTERVAL - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CHECKPOINTING_MODE - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CHECKPOINTING_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CheckpointingMode - org.apache.flink.streaming.api中的枚举
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures.
checkpointStarted(CheckpointBarrier) - 类 中的方法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>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
checkpointStopped(long) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
checkpointStorage - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
Our checkpoint storage.
checkSupportedInputCount(int) - 类 中的静态方法org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
clean(F) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
 
clean(F) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
clean(F) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Invokes the ClosureCleaner on the given function if closure cleaning is enabled in the ExecutionConfig.
clean(F) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns a "closure-cleaned" version of the given function.
cleanFile(String) - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
Creates target file if it does not exist, cleans it if it exists.
cleanUp(Throwable) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
cleanUpInternal() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cleanUpInternal() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cleanUpInternal() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
clear() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Remove all registered nodes etc.
clear() - 类 中的方法org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
clear(GlobalWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
clear(TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
 
clear(TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
clear(W, Trigger.TriggerContext) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - 接口 中的方法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() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
clear() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
clearJobListeners() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Clear all registered JobListeners.
client - 类 中的变量org.apache.flink.streaming.api.operators.collect.ClientAndIterator
 
ClientAndIterator<E> - 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>) - 类 的构造器org.apache.flink.streaming.api.operators.collect.ClientAndIterator
 
close() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Close and clean up the execution environment.
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.SocketClientSink
Closes the connection with the Socket server.
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
close() - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
This method is called by the system to shut down the context.
close() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.ClientAndIterator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
close() - 接口 中的方法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() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
close() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
 
close() - 类 中的方法org.apache.flink.streaming.experimental.CollectSink
Closes the connection with the Socket server.
close() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
Cleans up all internally held resources.
close() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
close() - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Closes the resource/connection to it.
close() - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
close() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
close() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Lifecycle method to close the mailbox for action submission/retrieval.
close() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Close the mailbox.
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
This method releases all resources of the record writer output.
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
close() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Close the operator.
closeAllOperators() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Execute StreamOperator.close() of each operator in the chain of this StreamTask.
closeAllOperators() - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
closePartFileForBucket(BucketID) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
closer - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
closeWith(DataStream<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.IterativeStream
Closes the iteration.
closeWith(DataStream<F>) - 类 中的方法org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
Closes the iteration.
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
CoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
CoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
CoFeedbackTransformation<F> - org.apache.flink.streaming.api.transformations中的类
This represents a feedback point in a topology.
CoFeedbackTransformation(int, TypeInformation<F>, Long) - 类 的构造器org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Creates a new CoFeedbackTransformation from the given input.
CoFlatMapFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的接口
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
coGroup(DataStream<T2>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Creates a join operation.
CoGroupedStreams<T1,T2> - org.apache.flink.streaming.api.datastream中的类
CoGroupedStreams represents two DataStreams that have been co-grouped.
CoGroupedStreams(DataStream<T1>, DataStream<T2>) - 类 的构造器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> - org.apache.flink.streaming.api.datastream中的类
Internal class for implementing tagged union co-group.
CoGroupedStreams.UnionSerializer<T1,T2> - org.apache.flink.streaming.api.datastream中的类
TypeSerializer for CoGroupedStreams.TaggedUnion.
CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2> - org.apache.flink.streaming.api.datastream中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by CoGroupedStreams.UnionSerializerSnapshot.
CoGroupedStreams.UnionSerializerSnapshot<T1,T2> - org.apache.flink.streaming.api.datastream中的类
The TypeSerializerSnapshot for the CoGroupedStreams.UnionSerializer.
CoGroupedStreams.Where<KEY> - org.apache.flink.streaming.api.datastream中的类
CoGrouped streams that have the key for one side defined.
CoGroupedStreams.Where.EqualTo - 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> - 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>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
collect(DataStream<OUT>, String) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
collect(T) - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits one element from the source, without attaching a timestamp.
collect(StreamRecord<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
Emits a record to the side output identified by the given OutputTag.
collect(T) - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
collect(T, long) - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
collect(T) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(StreamRecord<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(OUT) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
collectAsync() - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Sets up the collection of the elements in this DataStream, which can be retrieved later via the given DataStream.Collector.
collectBoundedStream(DataStream<E>, String) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
CollectCoordinationRequest - 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) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
CollectCoordinationRequest(DataInputView) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
CollectCoordinationResponse - 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[]>) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
CollectCoordinationResponse(DataInputView) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
Collector() - 类 的构造器org.apache.flink.streaming.api.datastream.DataStream.Collector
 
collectRecordsFromUnboundedStream(ClientAndIterator<E>, int) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
CollectResultFetcher<T> - 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) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
CollectResultIterator<T> - 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) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
CollectResultIterator(AbstractCollectResultBuffer<T>, CompletableFuture<OperatorID>, String, int) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
CollectSink<IN> - org.apache.flink.streaming.experimental中的类
A specialized data sink to be used by DataStreamUtils.collect().
CollectSink(InetAddress, int, TypeSerializer<IN>) - 类 的构造器org.apache.flink.streaming.experimental.CollectSink
Creates a CollectSink that will send the data to the specified host.
CollectSinkAddressEvent - org.apache.flink.streaming.api.operators.collect中的类
An OperatorEvent that passes the socket server address in the sink to the coordinator.
CollectSinkAddressEvent(InetSocketAddress) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
 
CollectSinkFunction<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) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
CollectSinkOperator<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) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
CollectSinkOperatorCoordinator - org.apache.flink.streaming.api.operators.collect中的类
OperatorCoordinator for CollectSinkFunction.
CollectSinkOperatorCoordinator(int) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
CollectSinkOperatorCoordinator.Provider - org.apache.flink.streaming.api.operators.collect中的类
CollectSinkOperatorFactory<IN> - org.apache.flink.streaming.api.operators.collect中的类
The Factory class for CollectSinkOperator.
CollectSinkOperatorFactory(TypeSerializer<IN>, String) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
CollectSinkOperatorFactory(TypeSerializer<IN>, String, MemorySize, Duration) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
CollectStreamSink<T> - org.apache.flink.streaming.api.operators.collect中的类
A DataStreamSink which is used to collect results of a data stream.
CollectStreamSink(DataStream<T>, CollectSinkOperatorFactory<T>) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
collectUnboundedStream(DataStream<E>, int, String) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
collectWithClient(DataStream<OUT>, String) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
已过时。
collectWithTimestamp(T, long) - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits one element from the source, and attaches the given timestamp.
CoMapFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的接口
A CoFlatMapFunction implements a map() transformation over two connected streams.
commit(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Commit a pre-committed transaction.
commit(Collection<Committer.CommitRequest<CommT>>) - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
 
commit(boolean, Committer<CommT>) - 接口 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableManager
Commits all due committables.
commitCheckpoint(int, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Mark the given checkpoint as completed in the resource.
CommitRequestImpl<CommT> - org.apache.flink.streaming.runtime.operators.sink.committables中的类
Internal implementation to commit a specific committable and handle the response.
CommitRequestImpl(CommT) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
CommitRequestImpl(CommT, int, CommitRequestState) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
CommitRequestState - org.apache.flink.streaming.runtime.operators.sink.committables中的枚举
Internal state of a committable.
CommittableCollector<CommT> - 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) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
 
CommittableCollectorSerializer<CommT> - org.apache.flink.streaming.runtime.operators.sink.committables中的类
The serializer for the CommittableCollector.
CommittableCollectorSerializer(SimpleVersionedSerializer<CommT>, int, int) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
 
CommittableManager<CommT> - org.apache.flink.streaming.runtime.operators.sink.committables中的接口
Internal wrapper to handle the committing of committables.
CommittableMessage<CommT> - org.apache.flink.streaming.api.connector.sink2中的接口
The message send from SinkWriter to Committer.
CommittableMessageSerializer<CommT> - org.apache.flink.streaming.api.connector.sink2中的类
The serializer to serialize CommittableMessages in custom operators.
CommittableMessageSerializer(SimpleVersionedSerializer<CommT>) - 类 的构造器org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
 
CommittableMessageTypeInfo<CommT> - org.apache.flink.streaming.api.connector.sink2中的类
The type information for the CommittableMessage to make it consumable from a DataStream.
CommittableSummary<CommT> - 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) - 类 的构造器org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
CommittableWithLineage<CommT> - org.apache.flink.streaming.api.connector.sink2中的类
Provides metadata.
CommittableWithLineage(CommT, Long, int) - 类 的构造器org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
 
CommitterOperatorFactory<CommT> - org.apache.flink.streaming.runtime.operators.sink中的类
A StreamOperatorFactory for CommitterOperator.
CommitterOperatorFactory(TwoPhaseCommittingSink<?, CommT>, boolean, boolean) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
 
commitUpToCheckpoint(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
commitUpToCheckpoint(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
ComparableAggregator<T> - org.apache.flink.streaming.api.functions.aggregation中的类
An AggregationFunction that computes values based on comparisons of Comparables.
ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
Comparator - org.apache.flink.streaming.api.functions.aggregation中的类
Internal comparator implementation, for use with ComparableAggregator.
Comparator() - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.Comparator
 
comparePriorityTo(InternalTimer<?, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
compareTo(TimestampedInputSplit) - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
compareTo(WindowOperator.Timer<K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
complete(Collection<OUT>) - 接口 中的方法org.apache.flink.streaming.api.functions.async.ResultFuture
Completes the result future with a collection of result objects.
complete() - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
completeExceptionally(Throwable) - 接口 中的方法org.apache.flink.streaming.api.functions.async.ResultFuture
Completes the result future exceptionally with an exception.
ConcatenatedExtract<FROM,OVER,TO> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
Combines two extractors which will be executed one after each other.
config - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
The execution configuration for this environment.
config - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
config - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
ConfigurableStreamPartitioner - org.apache.flink.streaming.runtime.partitioner中的接口
Interface for StreamPartitioner which have to be configured with the maximum parallelism of the stream transformation.
configuration - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Currently, configuration is split across multiple member variables and classes such as ExecutionConfig or CheckpointConfig.
configuration - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
The configuration of this streaming task.
configure(ReadableConfig) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(ReadableConfig) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(ReadableConfig, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(int) - 接口 中的方法org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
Configure the StreamPartitioner with the maximum parallelism of the down stream operator.
configure(int) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
configureBufferTimeout(StreamGraph, int, Transformation<T>, long) - 类 中的静态方法org.apache.flink.streaming.util.graph.StreamGraphUtils
Configure a stream node's buffer timeout according to the given transformation.
connect(DataStream<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Creates a new ConnectedStreams by connecting DataStream outputs of (possible) different types with each other.
connect(BroadcastStream<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Creates a new BroadcastConnectedStream by connecting the current DataStream or KeyedStream with a BroadcastStream.
ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - 类 的构造器org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
ConnectedStreams<IN1,IN2> - org.apache.flink.streaming.api.datastream中的类
ConnectedStreams represent two connected streams of (possibly) different data types.
ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - 类 的构造器org.apache.flink.streaming.api.datastream.ConnectedStreams
 
ContainingTaskDetails - org.apache.flink.streaming.runtime.tasks中的接口
Details about the operator containing task (such as StreamTask).
CONTENTS - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.ProcessFunction.Context
 
context - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
Context() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
 
Context(K, W) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
ContinuousEventTimeTrigger<W extends Window> - org.apache.flink.streaming.api.windowing.triggers中的类
A Trigger that continuously fires based on a given time interval.
ContinuousFileMonitoringFunction<OUT> - 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) - 类 的构造器org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit> - org.apache.flink.streaming.api.functions.source中的类
The operator that reads the splits received from the preceding ContinuousFileMonitoringFunction.
ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> - org.apache.flink.streaming.api.functions.source中的类
ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>, TypeInformation<OUT>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
ContinuousProcessingTimeTrigger<W extends Window> - 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) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
CoordinatedOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的接口
A factory class for the StreamOperators implementing OperatorEventHandler.
CoProcessFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的类
A function that processes elements of two streams and produces a single output one.
CoProcessFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.CoProcessFunction
 
CoProcessFunction.Context - org.apache.flink.streaming.api.functions.co中的类
CoProcessFunction.OnTimerContext - org.apache.flink.streaming.api.functions.co中的类
Information available in an invocation of CoProcessFunction.onTimer(long, OnTimerContext, Collector).
CoProcessOperator<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
copy(CoGroupedStreams.TaggedUnion<T1, T2>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(CoGroupedStreams.TaggedUnion<T1, T2>, CoGroupedStreams.TaggedUnion<T1, T2>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(IntervalJoinOperator.BufferEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(IntervalJoinOperator.BufferEntry<T>, IntervalJoinOperator.BufferEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(TimerHeapInternalTimer<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(TimerHeapInternalTimer<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
copy(GlobalWindow) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(GlobalWindow, GlobalWindow) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(TimeWindow) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy(TimeWindow, TimeWindow) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns a new committable collector that deep copies all internals.
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
copy(StreamElement) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(StreamElement, StreamElement) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(T) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a copy of this stream record.
copyTo(T, StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Copies this record into the new stream record.
CosineDistance<DATA> - org.apache.flink.streaming.api.functions.windowing.delta中的类
This delta function calculates the cosine distance between two given vectors.
CosineDistance() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
CosineDistance(Extractor<DATA, double[]>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
CoStreamFlatMap<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
CoStreamMap<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.CoStreamMap
 
CountEvictor<W extends Window> - org.apache.flink.streaming.api.windowing.evictors中的类
An Evictor that keeps up to a certain amount of elements.
CountingOutput<OUT> - org.apache.flink.streaming.api.operators中的类
Wrapping Output that updates metrics on the number of emitted elements.
CountingOutput(Output<StreamRecord<OUT>>, Counter) - 类 的构造器org.apache.flink.streaming.api.operators.CountingOutput
 
CountTrigger<W extends Window> - 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) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into tumbling count windows.
countWindow(long, long) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into sliding count windows.
countWindowAll(long) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into tumbling count windows.
countWindowAll(long, long) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into sliding count windows.
cover(TimeWindow) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Returns the minimal window covers both this window and the given window.
create(OperatorCoordinator.Context) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager.Provider
 
create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - 类 中的静态方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
A factory method for creating the InternalTimeServiceManagerImpl.
create(CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - 类 中的静态方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
 
create(String, TypeSerializer<T>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
create() - 类 中的静态方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
Creates a new GlobalWindows WindowAssigner that assigns all elements to the same GlobalWindow.
create() - 类 中的静态方法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() - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
 
create(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo) - 类 中的静态方法org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
Factory method for StreamTaskNetworkInput or RescalingStreamTaskNetworkInput depending on InflightDataRescalingDescriptor.
create(TaskInvokable, CheckpointedInputGate[], IOManager, MemoryManager, TaskIOMetricGroup, TwoInputStreamOperator<IN1, IN2, ?>, WatermarkGauge, WatermarkGauge, OperatorChain<?, ?>, StreamConfig, Configuration, Configuration, ExecutionConfig, ClassLoader, Counter, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo) - 类 中的静态方法org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
 
create() - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
The factory method; creates the value.
createAndRestore(List<? extends Collection<S>>) - 类 中的方法org.apache.flink.streaming.api.operators.BackendRestorerProcedure
Creates a new state backend and restores it from the provided set of state snapshot alternatives.
createBatch() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Creates a batch of mails that can be taken with TaskMailbox.tryTakeFromBatch().
createBatch() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
createBrokerIdString(JobID, String, int) - 类 中的静态方法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) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
已过时。
 
createBuckets(int) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
createBuckets(int) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
createBucketWriter() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
已过时。
 
createBucketWriter() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
createBucketWriter() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
createCheckpointBarrierHandler(CheckpointableTask, StreamConfig, SubtaskCheckpointCoordinator, String, List<IndexedInputGate>[], List<StreamTaskSourceInput<?>>, MailboxExecutor, TimerService) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
 
createCheckpointedMultipleInputGate(MailboxExecutor, List<IndexedInputGate>[], TaskIOMetricGroup, CheckpointBarrierHandler, StreamConfig) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
 
createCheckpointStorage(JobID) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
 
createExceptionTypePredicate(Class<? extends Throwable>) - 类 中的静态方法org.apache.flink.streaming.util.retryable.RetryPredicates
Creates a predicate on given exception type.
createExecutionEnvironment(Configuration) - 接口 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
Creates a StreamExecutionEnvironment from this factory.
createExecutor(int) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorFactory
Creates a new executor for the given priority.
createInput(InputFormat<OUT, ?>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Generic method to create an input data stream with InputFormat.
createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Generic method to create an input data stream with InputFormat.
createInputGate(List<IndexedInputGate>) - 类 中的静态方法org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
createInputProcessor(List<IndexedInputGate>[], StreamConfig.InputConfig[], WatermarkGauge[], Function<Integer, StreamPartitioner<?>>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
createInstance() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
createIterationSourceAndSink(int, int, int, long, int, int, ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
createJobGraph(StreamGraph) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
createJobGraph(ClassLoader, StreamGraph, JobID) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
 
createLocalEnvironment() - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(int) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(int, Configuration) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(Configuration) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironmentWithWebUI(Configuration) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a LocalStreamEnvironment for local program execution that also starts the web monitoring UI.
createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - 类 中的方法org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
 
createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - 类 中的方法org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
 
createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - 接口 中的方法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() - 接口 中的方法org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
Creates the hook that should be called by the checkpoint coordinator.
createNoOpEventTimeLogic(WatermarkStrategy<E>, MetricGroup) - 接口 中的静态方法org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
 
createOperator(StreamOperatorFactory<OUT>, StreamTask<OUT, ?>, StreamConfig, Output<StreamRecord<OUT>>, OperatorEventDispatcher) - 类 中的静态方法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) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
 
createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
createProcessingTimeService(MailboxExecutor) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceFactory
Creates a new processing time service with the mailbox executor.
createProgressiveEventTimeLogic(WatermarkStrategy<E>, MetricGroup, ProcessingTimeService, long) - 接口 中的静态方法org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
 
createRecordWriterDelegate(StreamConfig, Environment) - 类 中的静态方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
createRecursiveProductFieldAccessor(int, TypeInformation<T>, FieldAccessor<R, F>, ExecutionConfig) - 接口 中的方法org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
Returns a product FieldAccessor that does support recursion.
createRegisterTimerCallback(MailboxExecutor, TimerService) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
 
createRemoteEnvironment(String, int, String...) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createRemoteEnvironment(String, int, int, String...) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createRemoteEnvironment(String, int, Configuration, String...) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createResource() - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Creates/opens/connects to the resource that is used to store information.
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
createSimpleProductFieldAccessor(int, TypeInformation<T>, ExecutionConfig) - 接口 中的方法org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
Returns a product FieldAccessor that does not support recursion.
createStreamOperator(StreamOperatorParameters<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
createStreamOperator(StreamOperatorParameters<Object>) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - 接口 中的方法org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
The implementation should return an instance of OperatorEventHandler.
createStreamOperator(StreamOperatorParameters<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
Create the operator.
createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
 
createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
 
createStreamTaskStateInitializer() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator, String, CheckpointableTask, Clock, boolean, CheckpointableInput...) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
createWithSeparateOutputs(PushingAsyncDataInput.DataOutput<E>, WatermarkOutput, WatermarkOutput, TimestampAssigner<E>, WatermarkGenerator<E>) - 类 中的静态方法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) - 类 中的方法org.apache.flink.streaming.api.functions.sink.PrintSink
 
createWriter(Sink.InitContext) - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter
 
currentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
Returns the current processing time.
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current processing time.
currentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Returns the current processing time.
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
currentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.TimerService
Returns the current processing time.
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentProcessingTime() - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentProcessingTime() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
currentTransaction() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
currentWatermark() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
Returns the current event-time watermark.
currentWatermark() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentWatermark() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current event-time watermark.
currentWatermark() - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Returns the current event-time watermark.
currentWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
currentWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
currentWatermark() - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
currentWatermark() - 接口 中的方法org.apache.flink.streaming.api.TimerService
Returns the current event-time watermark.
currentWatermark() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentWatermark() - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentWatermark() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
CustomPartitionerWrapper<K,T> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
CustomSinkOperatorUidHashes - org.apache.flink.streaming.api.datastream中的类
This class is responsible to hold operator Uid hashes from the common operators of the sink.
CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder - org.apache.flink.streaming.api.datastream中的类
Builder to construct CustomSinkOperatorUidHashes.

D

DataGenerator<T> - org.apache.flink.streaming.api.functions.source.datagen中的接口
Stateful and re-scalable data generator.
DataGeneratorSource<T> - org.apache.flink.streaming.api.functions.source.datagen中的类
A data generator source that abstract data generator.
DataGeneratorSource(DataGenerator<T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
Creates a source that emits records by DataGenerator without controlling emit rate.
DataGeneratorSource(DataGenerator<T>, long, Long) - 类 的构造器org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
Creates a source that emits records by DataGenerator.
DataInputStatus - org.apache.flink.streaming.runtime.io中的枚举
It is an internal equivalent of InputStatus that provides additional non public statuses.
DataStream<T> - org.apache.flink.streaming.api.datastream中的类
A DataStream represents a stream of elements of the same type.
DataStream(StreamExecutionEnvironment, Transformation<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStream
Create a new DataStream in the given execution environment with partitioning set to forward by default.
DataStream.Collector<T> - org.apache.flink.streaming.api.datastream中的类
This class acts as an accessor to elements collected via DataStream.collectAsync(Collector).
DataStreamSink<T> - org.apache.flink.streaming.api.datastream中的类
A Stream Sink.
DataStreamSink(PhysicalTransformation<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSink
 
DataStreamSource<T> - org.apache.flink.streaming.api.datastream中的类
The DataStreamSource represents the starting point of a DataStream.
DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSource
 
DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String, Boundedness) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSource
The constructor used to create legacy sources.
DataStreamSource(SingleOutputStreamOperator<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSource
Constructor for "deep" sources that manually set up (one or more) custom configured complex operators.
DataStreamSource(StreamExecutionEnvironment, Source<T, ?, ?>, WatermarkStrategy<T>, TypeInformation<T>, String) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSource
Constructor for new Sources (FLIP-27).
DataStreamUtils - org.apache.flink.streaming.api.datastream中的类
A collection of utilities for DataStreams.
days(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of days.
dealWithResponse(CollectCoordinationResponse, long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
declineCheckpoint(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
declineCheckpoint(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
declineCheckpoint(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
DEFAULT - 类 中的静态变量org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
Default instance providing no custom sink operator hashes.
DEFAULT_BATCH_JOB_NAME - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_BUCKET_CHECK_INTERVAL - 类 中的静态变量org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
已过时。
 
DEFAULT_CHAINING_STRATEGY - 枚举 中的静态变量org.apache.flink.streaming.api.operators.ChainingStrategy
 
DEFAULT_CHECKPOINT_ID_OF_IGNORED_IN_FLIGHT_DATA - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
Default id of checkpoint for which in-flight data should be ignored on recovery.
DEFAULT_JOB_NAME - 类 中的静态变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
This constant does not fit well to batch runtime mode.
DEFAULT_LOWER_BOUND_MAX_PARALLELISM - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_MAX_CONCURRENT_CHECKPOINTS - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
The default limit of concurrently happening checkpoints: one.
DEFAULT_MIN_PAUSE_BETWEEN_CHECKPOINTS - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
The default minimum pause to be made between checkpoints: none.
DEFAULT_MODE - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
The default checkpoint mode: exactly once.
DEFAULT_SLOT_SHARING_GROUP - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_STREAMING_JOB_NAME - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_TIME_CHARACTERISTIC - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
The default timeout of a checkpoint attempt: 10 minutes.
DefaultBucketFactoryImpl<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
A factory returning buckets.
DefaultBucketFactoryImpl() - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
 
defaultLatencyMeasurementInterval - 类 中的变量org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Default timer interval in milliseconds for triggering mailbox latency measurement.
deleteCleanupTimer(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Deletes the cleanup timer set for the contents of the provided window.
deleteEventTimeTimer(N, long) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteEventTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
deleteEventTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
deleteEventTimeTimer(long) - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
deleteEventTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.TimerService
Deletes the event-time timer with the given trigger time.
deleteEventTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the event-time trigger for the given time.
deleteEventTimeTimer(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
deleteOnCancellation() - 枚举 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
Returns whether persistent checkpoints shall be discarded on cancellation of the job.
deleteProcessingTimeTimer(N, long) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteProcessingTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
deleteProcessingTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
deleteProcessingTimeTimer(long) - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
deleteProcessingTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.TimerService
Deletes the processing-time timer with the given trigger time.
deleteProcessingTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the processing time trigger for the given time.
deleteProcessingTimeTimer(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
DeltaEvictor<T,W extends Window> - org.apache.flink.streaming.api.windowing.evictors中的类
An Evictor that keeps elements based on a DeltaFunction and a threshold.
DeltaFunction<DATA> - org.apache.flink.streaming.api.functions.windowing.delta中的接口
This interface allows the implementation of a function which calculates the delta between two data points.
DeltaTrigger<T,W extends Window> - org.apache.flink.streaming.api.windowing.triggers中的类
A Trigger that fires based on a DeltaFunction and a threshold.
deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
deserializationDelegate - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
DeserializationSchema<T> - org.apache.flink.streaming.util.serialization中的接口
已过时。
Use DeserializationSchema instead.
deserialize(int, byte[]) - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
deserialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataInputView) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
deserialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataInputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
deserialize(IntervalJoinOperator.BufferEntry<T>, DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(GlobalWindow, DataInputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(TimeWindow, DataInputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(int, byte[]) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(StreamElement, DataInputView) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(byte[]) - 接口 中的方法org.apache.flink.streaming.util.serialization.DeserializationSchema
已过时。
Deserializes the byte message.
deserializeAccumulatorResult(byte[]) - 类 中的静态方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
disableChaining() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableCheckpointing() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Disables checkpointing.
disableOperatorChaining() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Disables operator chaining for streaming operators.
DiscardingSink<T> - org.apache.flink.streaming.api.functions.sink中的类
A stream sink that ignores all elements.
DiscardingSink() - 类 的构造器org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
dispose() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
dispose() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
 
doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
 
doubleGenerator(double, double) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
doubleGenerator(int, int) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
drain() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Finishes running all mails in the mailbox.
drain() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Drains the mailbox and returns all mails that were still enqueued.
drain() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
duplicate() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
DynamicEventTimeSessionWindows<T> - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that windows elements into sessions based on the timestamp of the elements.
DynamicEventTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
DynamicProcessingTimeSessionWindows<T> - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that windows elements into sessions based on the current processing time.
DynamicProcessingTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 

E

emitCompletedElement(TimestampedCollector<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
emitCompletedElement(TimestampedCollector<OUT>) - 接口 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
emitLatencyMarker(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.io.FinishedDataOutput
 
emitLatencyMarker(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
 
emitNext(PushingAsyncDataInput.DataOutput<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - 类 中的方法org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
emitNext(PushingAsyncDataInput.DataOutput<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - 接口 中的方法org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
Pushes the next element to the output from current data input, and returns the input status to indicate whether there are more available data in current input.
emitNext(PushingAsyncDataInput.DataOutput<T>) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
 
emitPeriodicWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
emitRecord(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.io.FinishedDataOutput
 
emitRecord(StreamRecord<T>) - 接口 中的方法org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitRecord(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
 
emitsProgressiveWatermarks() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits the given Watermark.
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
Emits a Watermark from an operator.
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.io.FinishedDataOutput
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.CountingOutput
 
emitWatermarkStatus(WatermarkStatus) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.io.FinishedDataOutput
 
emitWatermarkStatus(WatermarkStatus) - 接口 中的方法org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
 
EMPTY_RESULT_PREDICATE - 类 中的静态变量org.apache.flink.streaming.util.retryable.RetryPredicates
A predicate matches empty result which means an empty Collection.
ENABLE_CHECKPOINTS_AFTER_TASKS_FINISH - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
ENABLE_UNALIGNED - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
enableApproximateLocalRecovery(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Enables the approximate local recovery mode.
enableChangelogStateBackend(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enable the change log for current state backend.
enableCheckpointing(long) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode, boolean) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode) instead. Forcing checkpoints will be removed in the future.
enableCheckpointing() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
enableExternalizedCheckpoints(CheckpointConfig.ExternalizedCheckpointCleanup) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
enableTransactionTimeoutWarnings(double) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
enableUnalignedCheckpoints() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
endData(StopMode) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
endInput() - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
endInput(int) - 接口 中的方法org.apache.flink.streaming.api.operators.BoundedMultiInput
It is notified that no more data will arrive from the input identified by the inputId.
endInput() - 接口 中的方法org.apache.flink.streaming.api.operators.BoundedOneInput
It is notified that no more data will arrive from the input.
endInput(int) - 类 中的方法org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
 
endInput(int) - 类 中的方法org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
 
endInput(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
endInput(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Ends the main operator input specified by inputId).
endInput(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
endOperatorInput(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Ends an input of the operator contained by this wrapper.
environment - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
environment - 类 中的变量org.apache.flink.streaming.api.datastream.DataStream
 
environment - 类 中的变量org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.watermark.Watermark
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
equals(Object) - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
equalTo(KeySelector<T2, KEY>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
eraseTimestamp() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
EuclideanDistance<DATA> - org.apache.flink.streaming.api.functions.windowing.delta中的类
This delta function calculates the euclidean distance between two given points.
EuclideanDistance() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EuclideanDistance(Extractor<DATA, double[]>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EventTimeSessionWindows - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that windows elements into sessions based on the timestamp of the elements.
EventTimeSessionWindows(long) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
EventTimeTrigger - 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) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - 接口 中的方法org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - 接口 中的方法org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
EvictingWindowOperator<K,IN,OUT,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing中的类
A WindowOperator that also allows an Evictor to be used.
EvictingWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
evictor(Evictor<? super T, ? super W>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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> - 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 A pane is the bucket of elements that have the same key (assigned by the KeySelector) and same Window.
evictor(Evictor<? super T, ? super W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
Evictor.EvictorContext - org.apache.flink.streaming.api.windowing.evictors中的接口
A context object that is given to Evictor methods.
ExceptionInChainedOperatorException - org.apache.flink.streaming.runtime.tasks中的异常错误
A special exception that signifies that the cause exception came from a chained operator.
ExceptionInChainedOperatorException(Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
ExceptionInChainedOperatorException(String, Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
exceptionPredicate() - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.api.environment.LocalStreamEnvironment
 
execute(StreamGraph) - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
execute() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(StreamGraph) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(ThrowingRunnable<? extends Exception>, String, Object...) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
executeAndCollect() - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program asynchronously.
executeAsync(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution asynchronously.
executeAsync(StreamGraph) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution asynchronously.
executionAttemptFailed(int, int, Throwable) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
ExecutionCheckpointingOptions - org.apache.flink.streaming.api.environment中的类
Execution ConfigOption for configuring checkpointing related parameters.
ExecutionCheckpointingOptions() - 类 的构造器org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
ExponentialBackoffDelayRetryStrategy(int, long, long, double, Predicate<Collection<OUT>>, Predicate<Throwable>) - 类 的构造器org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
 
ExponentialBackoffDelayRetryStrategyBuilder(int, long, long, double) - 类 的构造器org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
 
EXTERNALIZED_CHECKPOINT - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
ExternallyInducedSource<T,CD> - 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 - org.apache.flink.streaming.api.checkpoint中的接口
Through the CheckpointTrigger, the source function notifies the Flink source operator when to trigger the checkpoint.
extract(Tuple) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
 
extract(FROM) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
extract(FROM) - 接口 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.Extractor
Extracts/Converts the given input to an object of the output type.
extract(Object) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
 
extract(Tuple) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
 
extract(Object) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
 
extract(Tuple) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
 
extract(T) - 接口 中的方法org.apache.flink.streaming.api.windowing.assigners.SessionWindowTimeGapExtractor
Extracts the session time gap.
extractAscendingTimestamp(T) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
已过时。
Extracts the timestamp from the given element.
extractFieldTypes(int[], TypeInformation<?>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.StreamProjection
 
ExtractionAwareDeltaFunction<DATA,TO> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
 
Extractor<FROM,TO> - org.apache.flink.streaming.api.functions.windowing.delta.extractor中的接口
Extractors allow to extract/convert one type to another.
extractTimestamp(T, long) - 类 中的方法org.apache.flink.streaming.api.functions.IngestionTimeExtractor
已过时。
 
extractTimestamp(T, long) - 接口 中的方法org.apache.flink.streaming.api.functions.TimestampAssigner
已过时。
Assigns a timestamp to an element, in milliseconds since the Epoch.
extractTimestamp(T, long) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
已过时。
 
extractTimestamp(T) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
Extracts the timestamp from the given element.
extractTimestamp(T, long) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 

F

FailingHandler() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
已过时。
 
fairSelectNextIndex(long, int) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the available inputs for reading.
fairSelectNextIndex(long, long, int) - 类 中的静态方法org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the available inputs for reading.
fairSelectNextIndexOutOf2(int, int) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the two inputs for reading.
fairSelectNextIndexOutOf2(int, int, int) - 类 中的静态方法org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the two inputs for reading.
FeedbackTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This represents a feedback point in a topology.
FeedbackTransformation(Transformation<T>, Long) - 类 的构造器org.apache.flink.streaming.api.transformations.FeedbackTransformation
Creates a new FeedbackTransformation from the given input.
FieldAccessor<T,F> - 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() - 类 的构造器org.apache.flink.streaming.util.typeutils.FieldAccessor
 
FieldAccessorFactory - org.apache.flink.streaming.util.typeutils中的类
Static factories for the FieldAccessor utilities.
FieldAccessorFactory() - 类 的构造器org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
 
FieldFromArray<OUT> - org.apache.flink.streaming.api.functions.windowing.delta.extractor中的类
Extracts a single field out of an array.
FieldFromArray() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
Extracts the first field (id 0) from the array.
FieldFromArray(int) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
Extracts the field with the given id from the array.
FieldFromTuple<OUT> - org.apache.flink.streaming.api.functions.windowing.delta.extractor中的类
Extracts a single field out of a tuple.
FieldFromTuple(int) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
Extracts the field with the given id from the tuple.
FieldsFromArray<OUT> - 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...) - 类 的构造器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 - 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...) - 类 的构造器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 - 类 中的变量org.apache.flink.streaming.util.typeutils.FieldAccessor
 
FileLifeCycleListener<BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
Listener about the status of file.
FileMonitoringFunction - org.apache.flink.streaming.api.functions.source中的类
已过时。
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - 类 的构造器org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
已过时。
 
FileMonitoringFunction.WatchType - org.apache.flink.streaming.api.functions.source中的枚举
已过时。
The watch type of the FileMonitoringFunction.
FileProcessingMode - org.apache.flink.streaming.api.functions.source中的枚举
The mode in which the ContinuousFileMonitoringFunction operates.
FileReadFunction - org.apache.flink.streaming.api.functions.source中的类
已过时。
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
FileReadFunction() - 类 的构造器org.apache.flink.streaming.api.functions.source.FileReadFunction
已过时。
 
filter(FilterFunction<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Applies a Filter transformation on a DataStream.
finalize() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
The finalize method shuts down the timer.
finalize() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
finish() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction
This method is called at the end of data processing.
finish() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
finish() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
finish() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
finish() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
finish() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
finish() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
finish() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
This method is called at the end of data processing.
finish() - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
finish(StreamTaskActionExecutor, StopMode) - 类 中的方法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> - org.apache.flink.streaming.runtime.io中的类
FinishedDataOutput() - 类 的构造器org.apache.flink.streaming.runtime.io.FinishedDataOutput
 
FinishedOnRestoreInput<IN> - org.apache.flink.streaming.runtime.tasks中的类
A fake Input for finished on restore tasks.
FinishedOnRestoreInput(RecordWriterOutput<?>[], int) - 类 的构造器org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
finishedOnRestoreInput - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
FinishedOnRestoreMainOperatorOutput<OUT> - org.apache.flink.streaming.runtime.tasks中的类
A fake main operator output that skips all the following operators for finished on restored tasks.
FinishedOnRestoreMainOperatorOutput(RecordWriterOutput<?>[]) - 类 的构造器org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> - 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>>>) - 类 的构造器org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
finishOperators(StreamTaskActionExecutor, StopMode) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
finishOperators(StreamTaskActionExecutor, StopMode) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Closes all operators in a chain effect way.
finishOperators(StreamTaskActionExecutor, StopMode) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
finishProcessing(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
This method is called at the end of data processing.
finishRecoveringContext(Collection<TXN>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Callback for subclasses which is called after restoring (each) user context.
finishRecovery() - 接口 中的方法org.apache.flink.streaming.runtime.io.RecoverableStreamTaskInput
 
finishRecovery() - 类 中的方法org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
 
FIRST - 类 中的静态变量org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select the first input.
firstOperatorWrapper - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
FixedDelayRetryStrategyBuilder(int, long) - 类 的构造器org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
 
flatMap(CoFlatMapFunction<IN1, IN2, R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Applies a FlatMap transformation on a DataStream.
flatMap(FlatMapFunction<T, R>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Applies a FlatMap transformation on a DataStream.
flatMap(Tuple3<String, Long, Long>, Collector<String>) - 类 中的方法org.apache.flink.streaming.api.functions.source.FileReadFunction
已过时。
 
flatMap1(IN1, Collector<OUT>) - 接口 中的方法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>) - 接口 中的方法org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
This method is called for each element in the second of the connected streams.
flattenedChannelIndices - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
floatGenerator(float, float) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
floatGenerator(short, short) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
flush() - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
flushOutputs() - 类 中的方法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>) - 类 中的静态方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
Creates the builder for a StreamingFileSink with bulk-encoding format.
FORCE_UNALIGNED - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
forceNonParallel() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism and maximum parallelism of this operator to one.
forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Performs an action for each registered timer.
forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Performs an action for each registered timer.
forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
forInputGate(InputGate) - 接口 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
 
format - 类 中的变量org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
 
forRowFormat(Path, Encoder<IN>) - 类 中的静态方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
Creates the builder for a StreamingFileSink with row-encoding format.
forSink(DataStream<T>, Sink<T>, CustomSinkOperatorUidHashes) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamSink
 
forSinkV1(DataStream<T>, Sink<T, ?, ?, ?>, CustomSinkOperatorUidHashes) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamSink
 
forTimestamp(long) - 类 中的静态方法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() - 类 中的方法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> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
Create a new ForwardForConsecutiveHashPartitioner.
ForwardForUnspecifiedPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
When the parallelism of both upstream and downstream is ExecutionConfig.PARALLELISM_DEFAULT and the edge's partitioner is not specified (partitioner==null), the edge's partitioner will be set to FORWARD by default(See StreamGraph.createActualEdge(java.lang.Integer, java.lang.Integer, int, org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<?>, org.apache.flink.util.OutputTag, org.apache.flink.streaming.api.transformations.StreamExchangeMode, org.apache.flink.runtime.jobgraph.IntermediateDataSetID) method for details).
ForwardForUnspecifiedPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
 
ForwardPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that forwards elements only to the locally running downstream operation.
ForwardPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
from(InputSelection) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a TimestampedValue from given StreamRecord.
fromCollection(Collection<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given non-empty collection.
fromCollection(Collection<OUT>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given non-empty collection.
fromCollection(Iterator<OUT>, Class<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given iterator.
fromCollection(Iterator<OUT>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given iterator.
fromElements(OUT...) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the given elements.
fromElements(Class<OUT>, OUT...) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the given elements.
FromElementsFunction<T> - org.apache.flink.streaming.api.functions.source中的类
A stream source function that returns a sequence of elements.
FromElementsFunction(TypeSerializer<T>, T...) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
FromElementsFunction(TypeSerializer<T>, Iterable<T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
FromElementsFunction(T...) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
FromElementsFunction(Iterable<T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
FromIteratorFunction<T> - org.apache.flink.streaming.api.functions.source中的类
A SourceFunction that reads elements from an Iterator and emits them.
FromIteratorFunction(Iterator<T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains elements in the iterator.
fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains elements in the iterator.
fromSequence(long, long) - 类 中的方法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) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a data Source to the environment to get a DataStream.
FromSplittableIteratorFunction<T> - org.apache.flink.streaming.api.functions.source中的类
A SourceFunction that reads elements from an SplittableIterator and emits them.
FromSplittableIteratorFunction(SplittableIterator<T>) - 类 的构造器org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 

G

GaugePeriodTimer - org.apache.flink.streaming.runtime.tasks.mailbox中的类
Implementation of PeriodTimer based on TimerGauge.
GaugePeriodTimer(TimerGauge) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
 
generate() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
generateOperatorDescription(Function, Function) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
generateOperatorName() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
generateSequence(long, long) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use StreamExecutionEnvironment.fromSequence(long, long) instead to create a new data stream that contains NumberSequenceSource.
generateStreamGraph(List<Transformation<?>>) - 类 中的方法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> - org.apache.flink.streaming.runtime.operators中的类
Generic Sink that emits its input elements into an arbitrary backend.
GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - 类 的构造器org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
get() - 类 中的方法org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
get() - 类 中的静态方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
get(K) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Looks up the value mapped under the given key.
get(T) - 类 中的方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
getActiveSerializer(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
 
getActiveTimerTimestamps() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getAddress() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getAlignedCheckpointTimeout() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
 
getAlignedCheckpointTimeout() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getAlignmentDurationNanos() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
getAlignmentTimeout() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
getAllBarriersReceivedFuture(long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
getAllBarriersReceivedFuture(long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
getAllBarriersReceivedFuture(long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
getAllFutures() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getAllOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getAllOperators() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Returns an Iterable which traverses all operators in forward topological order.
getAllOperators(boolean) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Returns an Iterable which traverses all operators in forward or reverse topological order.
getAllowedLateness() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
getArity() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
getAsyncCheckpointStartDelayNanos() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getAsyncOperationsThreadPool() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getAvailableFuture() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
 
getBackoffTimeMillis(int) - 接口 中的方法org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
 
getBackoffTimeMillis(int) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
 
getBackoffTimeMillis(int) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
 
getBindAddress() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
 
getBoundedness() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
getBoundedness() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
getBoundedness() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getBoundedness() - 接口 中的方法org.apache.flink.streaming.api.transformations.WithBoundedness
Returns the Boundedness of this Transformation.
getBroadcastInput() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getBroadcastState(MapStateDescriptor<K, V>) - 类 中的方法org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
Fetches the BroadcastState with the specified name.
getBroadcastState(MapStateDescriptor<K, V>) - 类 中的方法org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
Fetches a read-only view of the broadcast state with the specified name.
getBroadcastStateDescriptors() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getBroadcastStateDescriptors() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getBroadcastVariable(String) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getBrokerID(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getBucketCheckInterval() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
getBucketCheckInterval() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
getBucketId() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
getBucketPath() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the maximum time frequency (milliseconds) for the flushing of the output buffers.
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getCachedFiles() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Get the list of cached files that were registered for distribution among the task managers.
getCancelables() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getChainedOutputs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getChainedSource(StreamConfig.SourceInputConfig) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getChainedSourceOutputs() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getChainIndex() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
getChainingStrategy() - 接口 中的方法org.apache.flink.streaming.api.operators.SetupableStreamOperator
已过时。
 
getChainingStrategy() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
Get the chaining strategy of operator factory.
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getChainingStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
 
getChannel(int) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
getChannelInfos() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
getChannelInfos() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getChannelStateWriter() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
getCheckpointBarrierHandler() - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
getCheckpointBarrierHandler() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
getCheckpointBarrierHandler() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Acquires the optional CheckpointBarrierHandler associated with this stream task.
getCheckpointBarrierHandler() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
getCheckpointCommittablesUpTo(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns all CheckpointCommittableManager until the requested checkpoint id.
getCheckpointConfig() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the checkpoint config, which defines values like checkpoint interval, delay between checkpoints, etc.
getCheckpointConfig() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getCheckpointId() - 接口 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessage
Returns the checkpoint id or empty if the message does not belong to a checkpoint.
getCheckpointId() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getCheckpointId() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
 
getCheckpointId() - 接口 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
Returns the checkpoint id in which the committable was created.
getCheckpointIdOfIgnoredInFlightData() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
 
getCheckpointingMode() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the checkpointing mode (exactly-once vs. at-least-once).
getCheckpointingMode() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the checkpointing mode (exactly-once vs. at-least-once).
getCheckpointInterval() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the interval in which checkpoints are periodically scheduled.
getCheckpointInterval() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the checkpointing interval or -1 if checkpointing is disabled.
getCheckpointLock() - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Returns the checkpoint lock.
getCheckpointMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getCheckpointMode() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the checkpointing mode.
getCheckpointStartDelayNanos() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
getCheckpointStorage() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
 
getCheckpointStorage(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getCheckpointStorage() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getCheckpointStorage() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getCheckpointStorage() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
getCheckpointTimeout() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the maximum time that a checkpoint may take before being discarded.
getClientConfiguration() - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
已过时。
This method is going to be removed in the next releases.
getClock() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
getCollector() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
getCollector() - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
getCollector() - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
getCoLocationGroup() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getCommittable() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
 
getCommittable() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
getCommitterUidHash() - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
 
getCompatibleVersions() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
getCompletionFuture() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
getCompletionFuture() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getConfig() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config object.
getConfiguration() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gives read-only access to the underlying configuration of this environment.
getConfiguration() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getConfiguration() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getConsumeClusterDatasetId() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getConsumerMaxParallelism() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getConsumerParallelism() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getContainedTypeSerializer() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
getContainingTask() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getContainingTask() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getCoordinatorListeningID() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getCoordinatorProvider(String, OperatorID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getCoordinatorProvider(String, OperatorID) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
getCoordinatorProvider(String, OperatorID) - 接口 中的方法org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
Get the operator coordinator provider for this operator.
getCoordinatorProvider(String, OperatorID) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
Get the key of the firing timer.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
Get key of the element being processed.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Get key of the element being processed.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
Get key of the firing timer.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Get key of the element being processed.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
Get key of the firing timer.
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getCurrentKey() - 接口 中的方法org.apache.flink.streaming.api.operators.KeyContext
 
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getCurrentKey() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
getCurrentProcessingTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
Returns the current processing time.
getCurrentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the current processing time.
getCurrentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the current processing time.
getCurrentProcessingTime() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getCurrentProcessingTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
getCurrentProcessingTime() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getCurrentTableCapacity() - 类 中的方法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() - 接口 中的方法org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
已过时。
Returns the current watermark.
getCurrentWatermark() - 类 中的方法org.apache.flink.streaming.api.functions.IngestionTimeExtractor
已过时。
 
getCurrentWatermark() - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
已过时。
 
getCurrentWatermark() - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
getCurrentWatermark() - 接口 中的方法org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the current watermark time.
getCurrentWatermark() - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the current watermark time.
getCurrentWatermark() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getDataSetId() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getDatasetId() - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
getDefaultBufferTimeout() - 接口 中的方法org.apache.flink.streaming.api.graph.TransformationTranslator.Context
Returns the default buffer timeout to be used.
getDefaultLocalParallelism() - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
getDefaultSavepointDirectory() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the default savepoint directory for this Job.
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns the default trigger associated with this WindowAssigner.
getDelta(DATA, DATA) - 接口 中的方法org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
Calculates the delta between two given data points.
getDelta(DATA, DATA) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
This method takes the two data point and runs the set extractor on it.
getDescription() - 枚举 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
Defines the behavior of this partitioner, when downstream rescaled during recovery of in-flight data.
getElement() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
getEnd() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the end timestamp of this window.
getEndOfInputCommittable() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns CheckpointCommittableManager that is currently hold by the collector and associated with the CommittableCollector.EOI checkpoint id.
getEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getEnvironment() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getEvictor() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
getExchangeMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getExchangeMode() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
getExecutionConfig() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
 
getExecutionConfig() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getExecutionConfig() - 类 中的方法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() - 类 中的方法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() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
 
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
 
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
 
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
 
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Returns the StreamExecutionEnvironment that was used to create this DataStream.
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
getExecutionEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
 
getExecutionEnvironment() - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment(Configuration) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionPlan() - 类 中的方法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.
getExpandedSinkIds() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getExternalizedCheckpointCleanup() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Returns the cleanup behaviour for externalized checkpoints.
getExternalResourceInfos(String) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getFeedbackEdges() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the list of feedback Transformations.
getFeedbackEdges() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the list of feedback Transformations.
getFieldType() - 类 中的方法org.apache.flink.streaming.util.typeutils.FieldAccessor
Gets the TypeInformation for the type of the field.
getFinishedOnRestoreInputOrDefault(Input) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getFirstInput() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Returns the non-broadcast DataStream.
getFirstInput() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the first DataStream.
getForAggregation(AggregationFunction.AggregationType) - 类 中的静态方法org.apache.flink.streaming.api.functions.aggregation.Comparator
 
getForClass(Class<?>) - 类 中的静态方法org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
getFormat() - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
getFormat() - 类 中的方法org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
Returns the InputFormat.
getGlobalAggregateManager() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the global aggregate manager for the current job.
getGlobalCommittableSerializer() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
 
getGlobalCommitter() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkV1Adapter.GlobalCommitterAdapter
 
getGlobalCommitterUidHash() - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
 
getGlobalModificationTime() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
getGlobalStreamExchangeMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getGraphGeneratorConfig() - 接口 中的方法org.apache.flink.streaming.api.graph.TransformationTranslator.Context
Retrieves additional configuration for the graph generation process.
getHashPartitioner() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
 
getHost() - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the hostname of the master (JobManager), where the program will be executed.
getId() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Returns the ID of the DataStream in the current StreamExecutionEnvironment.
getId() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getIndexInSubtaskGroup() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
 
getInEdgeIndices() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getInEdges() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getInPhysicalEdges(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getInput1() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input Transformation of this TwoInputTransformation.
getInput2() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the second input Transformation of this TwoInputTransformation.
getInputChannelStateFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getInputChannelStatus(int) - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
 
getInputEdge() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
 
getInputFormat() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getInputFormat() - 接口 中的方法org.apache.flink.streaming.api.operators.InputFormatOperatorFactory
 
getInputFormat() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
 
getInputGateIndex() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
 
getInputGateIndex() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getInputIndex() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
getInputIndex() - 类 中的方法org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
getInputIndex() - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
getInputIndex() - 接口 中的方法org.apache.flink.streaming.runtime.io.StreamTaskInput
Returns the input index of this input.
getInputIndex() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getInputMask() - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
 
getInputRequirement() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
 
getInputRequirements() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getInputs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getInputs() - 接口 中的方法org.apache.flink.streaming.api.operators.MultipleInputStreamOperator
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.UnionTransformation
 
getInputSelectable() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
 
getInputSplitProvider() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the input split provider associated with the operator.
getInputStream() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getInputType() - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
 
getInputType() - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
 
getInputType() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the TypeInformation for the elements of the input.
getInputType() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
Returns the TypeInformation for the elements of the input.
getInputType() - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
Returns the TypeInformation for the elements of the input.
getInputType1() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TypeInformation for the elements from the first input.
getInputType2() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TypeInformation for the elements from the second input.
getInputTypes() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
Returns the TypeInformation for the elements from the inputs.
getIntermediateDatasetIdToProduce() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getInternalIndex() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - 类 中的方法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>) - 类 中的方法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>) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
Creates an InternalTimerService for handling a group of timers identified by the given name.
getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 
getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
 
getInterval() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
getInterval() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
getIterationId() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
getIterationSourceSinkPairs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getIterationWaitTime() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getJobConfiguration() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
 
getJobGraph() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Gets the assembled JobGraph with a random JobID.
getJobGraph(ClassLoader, JobID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Gets the assembled JobGraph with a specified JobID.
getJobId() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getJobListeners() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config JobListeners.
getJobManagerOwnedState() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
getJobName() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getJobStatusHooks() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getJobType() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getJobVertexClass() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getJSON() - 类 中的方法org.apache.flink.streaming.api.graph.JSONGenerator
 
getKey() - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimer
Returns the key that is bound to this timer.
getKey() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getKey() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
 
getKey(IN) - 类 中的方法org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
 
getKey(IN) - 类 中的方法org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
 
getKey(IN) - 类 中的方法org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
 
getKeyedStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getKeyedStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getKeyedStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getKeyedStateManagedFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateRawFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateStore() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getKeyedStateStore() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getKeyedStateStore() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getKeyGroupRange() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getKeys(String, N) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getKeysAndNamespaces(String) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getKeySelector() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
 
getKeySelector() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getKeySelector() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getKeySerializer() - 类 中的方法org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the key serializer for the queryable state instance.
getKeySerializer() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
getKeySerializer() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getKeySerializer() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
getKeySerializerSnapshot() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getKeyType() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Gets the type of the key by which the stream is partitioned.
getKeyTypeInfo() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getKeyValueState(String, Class<S>, S) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
getKeyValueState(String, TypeInformation<S>, S) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
getKeyValueState(String, Class<S>, S) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getKeyValueState(String, TypeInformation<S>, S) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getLastCheckpointedOffset() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getLatestCheckpointId() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
getLatestCheckpointId() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
getLatestCheckpointId() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
getLeftTimestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getLegacyTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
 
getLength() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
getLength() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
getLength() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
getListState(ListStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getListState(ListStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getLog2TableCapacity() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the base-2 logarithm of the hash table capacity, as returned by KeyMap.getCurrentTableCapacity().
getLoopTimeout(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getMailboxExecutor() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
Provides the mailbox executor iff this factory implements YieldingOperatorFactory.
getMailboxExecutor(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Returns an executor service facade to submit actions to the mailbox.
getMailboxExecutorFactory() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getMailboxMetricsControl() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Gets MailboxMetricsController for control and access to mailbox metrics.
getMailCounter() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Gets Counter for number of mails processed.
getMainMailboxExecutor() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
getMainOperator() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getMainOperatorOutput() - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
getMainOperatorOutput() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getManagedMemoryFractionOperatorUseCaseOfSlot(ManagedMemoryUseCase, Configuration, ClassLoader) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getManagedMemorySlotScopeUseCases() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getMapState(MapStateDescriptor<UK, UV>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getMapState(MapStateDescriptor<UK, UV>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getMarkedTime() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
Returns the timestamp marked by the LatencyMarker.
getMaxConcurrentCheckpoints() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
getMaxOutOfOrdernessInMillis() - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
getMaxParallelism() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the maximum degree of parallelism defined for the program.
getMaxParallelism() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
getMaxPartCounter() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
getMergingWindowSet() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Retrieves the MergingWindowSet for the currently active key.
getMetricGroup() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getMetricGroup() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getMetricGroup() - 类 中的方法org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
 
getMetricGroup() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
getMetricGroup() - 接口 中的方法org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the metric group for this Evictor.
getMetricGroup() - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the metric group for this Trigger.
getMetricGroup() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getMinPauseBetweenCheckpoints() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the minimal pause between checkpointing attempts.
getMinResources() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Gets the minimum resources for this operator.
getMinResources() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getModificationTime() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getModificationTime() - 接口 中的方法org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
 
getMutex() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
已过时。
 
getName() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Gets the name of the current data stream.
getName() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Gets the name of the task, in the form "taskname (2/5)".
getNamespace() - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimer
Returns the namespace that is bound to this timer.
getNamespace() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getNamespaceSerializer() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
getNamespaceSerializer() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
getNamespaceSerializerSnapshot() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getNestedDelta(double[], double[]) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
getNestedDelta(double[], double[]) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
getNestedDelta(TO, TO) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
This method is exactly the same as DeltaFunction.getDelta(Object, Object) except that it gets the result of the previously done extractions as input.
getNestedSerializers(CoGroupedStreams.UnionSerializer<T1, T2>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
getNestedSerializers(IntervalJoinOperator.BufferEntrySerializer<T>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
getNestedSerializers(TimerSerializer<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
getNestedSerializers(StreamElementSerializer<T>) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
getNestedTrigger() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
 
getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
 
getNewIterationNodeId() - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
getNumActiveTimers() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getNumberOfCommittables() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getNumberOfExecutionRetries() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
This method will be replaced by StreamExecutionEnvironment.getRestartStrategy().
getNumberOfFailedCommittables() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getNumberOfInputChannels() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
getNumberOfInputChannels() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getNumberOfNetworkInputs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfOperators() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getNumberOfOutputs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfPendingCommittables() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getNumberOfRetries() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
getNumberOfSubtasks() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getNumberOfSubtasks() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns number of subtasks.
getNumElements() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
Gets the number of elements produced in total by this function.
getNumElementsEmitted() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
Gets the number of elements emitted so far.
getOffset() - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
getOffset() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
getOne() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getOperator() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getOperatorConfig() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorConfig() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorDescription() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOperatorEventDispatcher() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getOperatorEventDispatcher() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getOperatorEventGateway(OperatorID) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
 
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
Returns the StreamOperatorFactory of this LegacySinkTransformation.
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
Returns the StreamOperatorFactory of this LegacySourceTransformation.
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorFactory() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorID() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorID() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorID() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorId() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
getOperatorID() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
getOperatorID() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getOperatorId() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
getOperatorIdFuture() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
getOperatorName() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorName() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOperatorName() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
Return the operator name.
getOperatorName() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Return the operator name.
getOperatorNonChainedOutputs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getOperatorStateManagedFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getOperatorStateRawFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getOperatorUniqueID() - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getOutEdgeIndices() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutEdges() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutput() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream.Collector
Returns an iterator over the collected elements.
getOutput() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getOutputFormat() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutputFormat() - 接口 中的方法org.apache.flink.streaming.api.operators.OutputFormatOperatorFactory
 
getOutputFormat() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
 
getOutputTag() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getOutputTag() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getOutputTag() - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getParallelism() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Gets the parallelism for this operator.
getParallelism() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the parallelism with which operation are executed by default.
getParallelism() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getPartCounter() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
getPartitionedState(StateDescriptor<S, ?>) - 类 中的方法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, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
Creates a partitioned state handle, using the state backend configured for this task.
getPartitionedState(StateDescriptor<S, ?>) - 类 中的方法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, ?>) - 类 中的方法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, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
Creates a partitioned state handle, using the state backend configured for this task.
getPartitionedState(StateDescriptor<S, ?>) - 接口 中的方法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, ?>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getPartitionedState(StateDescriptor<S, ?>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getPartitioner() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getPartitioner() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getPartitioner() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the StreamPartitioner that must be used for partitioning the elements of the input Transformation.
getPartitionType() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getPassThroughInputs() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
 
getPendingCommitTransactions() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getPendingTransaction() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getPersistentDataSetId() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getPort() - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the port of the master (JobManager), where the program will be executed.
getPort() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
Returns the port on which the iterator is getting the data.
getPreferredResources() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Gets the preferred resources for this operator.
getPreferredResources() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getPriority() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
getProcessingTimeDelay(long, long) - 类 中的静态方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
Returns the remaining delay of the processing time specified by processingTimestamp.
getProcessingTimeService() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
Returns the ProcessingTimeService responsible for getting the current processing time and registering timers.
getProcessingTimeService() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Returns the ProcessingTimeService responsible for getting the current processing time and registering timers.
getProcessingTimeService() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getProcessingTimeService() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getProcessingTimeServiceFactory() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getProducedType() - 类 中的方法org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
 
getProducedType() - 类 中的方法org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
 
getQueryableStateName() - 类 中的方法org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the name under which the state can be queried.
getReaderForVersion(int, ClassLoader) - 类 中的静态方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
getReducer() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getRegularInput() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getRehashThreshold() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getRestartStrategy() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the specified restart strategy configuration.
getRestoredCheckpointId() - 接口 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getResultSubpartitionStateFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getRetryPredicate() - 接口 中的方法org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
 
getRetryPredicate() - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
 
getRetryPredicate() - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
 
getRightTimestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getRuntimeContext() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
getRuntimeContext() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
getSavepointDir(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getSavepointDirectory() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSavepointRestoreSettings() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSecondInput() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Returns the BroadcastStream.
getSecondInput() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the second DataStream.
getSelectorForArray(int[], TypeInformation<X>) - 类 中的静态方法org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - 类 中的静态方法org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - 类 中的静态方法org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSerializationFuture() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getSerializer() - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
getShift() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getSideOutput(OutputTag<X>) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getSink() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
 
getSinkIDs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSinkOperatorsUidHashes() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getSize() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getSize() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getSize() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getSize() - 类 中的方法org.apache.flink.streaming.api.windowing.time.Time
Gets the length of this policy's time interval.
getSlide() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getSlide() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getSlotSharingGroup(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Determines the slot sharing group of an operation across virtual nodes.
getSlotSharingGroup() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getSlotSharingGroup() - 接口 中的方法org.apache.flink.streaming.api.graph.TransformationTranslator.Context
Returns the slot sharing group for the given transformation.
getSlotSharingGroupResource(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSortedInputs() - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
 
getSource() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, Output<StreamRecord<OUT>>, long, long, boolean) - 类 中的静态方法org.apache.flink.streaming.api.operators.StreamSourceContexts
Depending on the TimeCharacteristic, this method will return the adequate SourceFunction.SourceContext.
getSourceId() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getSourceIDs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSourceMetricGroup() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
getSourceNodeId() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
getSourceOutput() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
 
getSourceReader() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
getSourceTaskInput() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
 
getSourceTaskInput(StreamConfig.SourceInputConfig) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getSourceTaskInputs() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getSourceVertex(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSplitState() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getSplitState() - 接口 中的方法org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
 
getStaggerOffset(long, long) - 枚举 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowStagger
 
getStart() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the starting timestamp of the window.
getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getState() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns the current state of the mailbox as defined by the lifecycle enum TaskMailbox.State.
getState() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
getStateBackend() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the state backend that defines how to store and checkpoint state.
getStateBackend(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStateBackend() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStateDescriptor() - 类 中的方法org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the state descriptor for the queryable state instance.
getStateDescriptor() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
getStateDescriptor() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getStateKeySelector() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Sink.
getStateKeySelector() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Operation.
getStateKeySelector1() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
getStateKeySerializer(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStateKeySerializer() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getStatePartitioner(int, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStatePartitioners() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getStateWindow(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Returns the state window for the given in-flight Window.
getStatus() - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
getStreamConfig() - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getStreamEdges(int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamEdges(int, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamEdgesOrThrow(int, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
已过时。
getStreamGraph() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamGraph(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job with the option to clear previously registered transformations.
getStreamGraph() - 接口 中的方法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() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNode(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNodeIds(Transformation<?>) - 接口 中的方法org.apache.flink.streaming.api.graph.TransformationTranslator.Context
Returns the ids of the nodes in the StreamGraph corresponding to the provided transformation.
getStreamNodes() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamOperator(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStreamOperator() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
getStreamOperatorClass(ClassLoader) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
Returns the runtime class of the stream operator.
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
 
getStreamOperatorFactory(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStreamOutputs() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getStreamRecord() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a StreamRecord from this TimestampedValue.
getStreamTimeCharacteristic() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
getSubtaskId() - 接口 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessage
The subtask that created this committable.
getSubtaskId() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableSummary
 
getSubtaskId() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
 
getSubtaskId() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns subtask id.
getSubtaskIndex() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
getSummary() - 接口 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableManager
Returns a summary of the current commit progress.
getTailOperator() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getTargetId() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getTargetVertex(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getTaskLocalState() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
getTaskManagerRuntimeInfo() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the task manager runtime info of the task manager running this stream task.
getTimeCharacteristic() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTimeCharacteristic() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getTimerDelay(Clock, CheckpointBarrier) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
 
getTimerServiceProvider(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTimerServiceProvider() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getTimeServiceManager() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getTimeServiceManager() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getTimestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getTimestamp() - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimer
Returns the timestamp of the timer.
getTimestamp() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getTimestamp() - 类 中的方法org.apache.flink.streaming.api.watermark.Watermark
Returns the timestamp associated with this Watermark in milliseconds.
getTimestamp() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
 
getTimestamp() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Returns the timestamp associated with this stream value in milliseconds.
getTolerableCheckpointFailureNumber() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
getTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Returns the Transformation that represents the operation that logically creates this DataStream.
getTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Returns the transformation that contains the actual sink operator of this sink.
getTransformations() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
getTransformationToCache() - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
getTransformationUID() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getTransitiveChainedTaskConfigs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTransitiveChainedTaskConfigsWithSelf(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.UnionTransformation
 
getTrigger() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getTwo() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
getType() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getType() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Gets the type of the stream.
getType1() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Gets the type of the first input.
getType1() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
Gets the type of the first input.
getType2() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Gets the type of the second input.
getType2() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
Gets the type of the second input.
getTypeClass() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
getTypeNumber() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getTypeSerializer() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
 
getTypeSerializerIn(int, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn1(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
已过时。
getTypeSerializerIn2(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
已过时。
getTypeSerializerOut(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerOut() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializersIn() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getUnit() - 类 中的方法org.apache.flink.streaming.api.windowing.time.Time
Gets the time unit for this policy's time interval.
getUpstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
getUpstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
getUpstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
getUpstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
Defines the behavior of this partitioner, when upstream rescaled during recovery of in-flight data.
getUserArtifacts() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getUserClassloader() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
getUserCodeClassloader() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getUserCodeClassloader() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
 
getUserContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
getUserFunction() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
Gets the user function executed in this operator.
getUserFunction() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
getUserFunction() - 接口 中的方法org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
 
getUserFunction() - 类 中的方法org.apache.flink.streaming.api.transformations.BroadcastStateTransformation
 
getUserFunction() - 类 中的方法org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
 
getUserFunctionClassName() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
getUserFunctionClassName() - 接口 中的方法org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
 
getUserFunctionParameters() - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getValue() - 类 中的方法org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
 
getValue() - 类 中的方法org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
getValue() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
 
getValue() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
 
getValue() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Returns the value wrapped in this stream value.
getVersion() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
 
getVersion() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
已过时。
 
getVertexDescriptionMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getVertexID() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getVertexIDs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getVertexNonChainedOutputs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getWaitTime() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the wait time.
getWaitTime() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the wait time.
getWatermarkGauge() - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
getWatermarkGauge() - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
 
getWatermarkGauge() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.WatermarkGaugeExposingOutput
 
getWatermarkStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
getWatermarkStrategy() - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
Returns the WatermarkStrategy to use.
getWindowAssigner() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a TypeSerializer for serializing windows that are assigned by this WindowAssigner.
getWindowSize() - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
getWindowStartWithOffset(long, long, long) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
getWriterUidHash() - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
 
global() - 类 中的方法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 - 类 中的静态变量org.apache.flink.streaming.api.connector.sink2.StandardSinkTopologies
 
GlobalPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that sends all elements to the downstream operator with subtask ID=0.
GlobalPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
globalState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
globalState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
globalState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key global state.
globalState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key global state.
globalState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
globalState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
globalState() - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
globalState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
GlobalStreamExchangeMode - org.apache.flink.streaming.api.graph中的枚举
This mode decides the default ResultPartitionType of job edges.
GlobalWindow - org.apache.flink.streaming.api.windowing.windows中的类
The default window into which all data is placed (via GlobalWindows).
GlobalWindow.Serializer - org.apache.flink.streaming.api.windowing.windows中的类
A TypeSerializer for GlobalWindow.
GlobalWindow.Serializer.GlobalWindowSerializerSnapshot - org.apache.flink.streaming.api.windowing.windows中的类
Serializer configuration snapshot for compatibility and format evolution.
GlobalWindows - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that assigns all elements to the same GlobalWindow.
GlobalWindows.NeverTrigger - org.apache.flink.streaming.api.windowing.assigners中的类
A trigger that never fires, as default Trigger for GlobalWindows.
GlobalWindowSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer.GlobalWindowSerializerSnapshot
 

H

handleAsyncException(String, Throwable) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Handles an exception thrown by another thread (e.g. a TriggerTask), other than the one executing the main task by failing the task entirely.
handleCoordinationRequest(CoordinationRequest) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
handleEndOfRecovery(InputChannelInfo) - 接口 中的方法org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
 
handleEventFromOperator(int, int, OperatorEvent) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
handleOperatorEvent(OperatorEvent) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
handleOperatorEvent(OperatorEvent) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
handleViolation(long, long) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
已过时。
 
handleViolation(long, long) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
已过时。
 
handleViolation(long, long) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
已过时。
 
handleViolation(long, long) - 接口 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.MonotonyViolationHandler
已过时。
Called when the property of monotonously ascending timestamps is violated, i.e., when elementTimestamp < lastTimestamp.
HAS_EXCEPTION_PREDICATE - 类 中的静态变量org.apache.flink.streaming.util.retryable.RetryPredicates
A predicate matches any exception which means a non-nullThrowable.
hasBeenJoined() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
hasBroadcastVariable(String) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
hasCompletedElements() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
hasCompletedElements() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Checks if there is at least one completed head element.
hasCompletedElements() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
hasFineGrainedResource() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.watermark.Watermark
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
hasMail() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
hasMail() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns true if the mailbox contains mail.
hasMail() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
hasNext() - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
hasNext() - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
hasNext() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
hasNext() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
Returns true if the DataStream has more elements.
hasReceivedEndOfData() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
hasTimestamp() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Checks whether this record has a timestamp.
hasTimestamp() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Checks whether this record has a timestamp.
hours(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of hours.

I

ID - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
IdentityStreamOperator() - 类 的构造器org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
 
IDLE - 类 中的静态变量org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
IDLE_STATUS - 类 中的静态变量org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
ifException(Predicate<Throwable>) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
 
ifException(Predicate<Throwable>) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
 
ifResult(Predicate<Collection<OUT>>) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
 
ifResult(Predicate<Collection<OUT>>) - 类 中的方法org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
 
ignoreFailuresAfterTransactionTimeout() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
If called, the sink will only log but not propagate exceptions thrown in TwoPhaseCommitSinkFunction.recoverAndCommit(Object) if the transaction is older than a specified transaction timeout.
IgnoringHandler() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
已过时。
 
IMMEDIATE - 接口 中的静态变量org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
inEventTime() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
Sets the time characteristic to event time.
IngestionTimeExtractor<T> - org.apache.flink.streaming.api.functions中的类
已过时。
IngestionTimeExtractor() - 类 的构造器org.apache.flink.streaming.api.functions.IngestionTimeExtractor
已过时。
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
initializeContextEnvironment(StreamExecutionEnvironmentFactory) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
initializeOperatorState(StreamOperatorStateHandler.CheckpointedStreamOperator) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
initializeState(FunctionInitializationContext) - 接口 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
Initializes the state after recovery from a failure.
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
initializeState(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
Stream operators with state which can be restored need to override this hook method.
initializeState(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Stream operators with state which can be restored need to override this hook method.
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
initializeState(StreamTaskStateInitializer) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
Provides a context to initialize all state in the operator.
initializeState(StateInitializationContext) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
initializeStateAndOpenOperators(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
initializeStateAndOpenOperators(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
Initialize state and open all operators in the chain from tail to heads, contrary to StreamOperator.close() which happens heads to tail (see OperatorChain.finishOperators(StreamTaskActionExecutor, StopMode)).
initializeStateAndOpenOperators(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
initializeUserContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
initInputsCheckpoint(long, CheckpointOptions) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Initialize new checkpoint.
initReader() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
Initializes the reader.
initSourceMetricGroup() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
inProcessingTime() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
Sets the time characteristic to processing time.
Input<IN> - org.apache.flink.streaming.api.operators中的接口
input1WatermarkGauge - 类 中的变量org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
input2WatermarkGauge - 类 中的变量org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
InputChannelStatus() - 类 的构造器org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
 
InputFormatOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的接口
Input format source operator factory.
InputFormatSourceFunction<OUT> - org.apache.flink.streaming.api.functions.source中的类
A SourceFunction that reads data using an InputFormat.
InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
InputGateUtil - org.apache.flink.streaming.runtime.io中的类
Utility for dealing with input gates.
inputId - 类 中的变量org.apache.flink.streaming.api.operators.AbstractInput
 
inputIndex - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
inputProcessor - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
The input processor.
InputProcessorUtil - org.apache.flink.streaming.runtime.io.checkpointing中的类
Utility for creating CheckpointedInputGate based on checkpoint mode for StreamOneInputProcessor.
InputProcessorUtil() - 类 的构造器org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
 
inputs - 类 中的变量org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
InputSelectable - org.apache.flink.streaming.api.operators中的接口
Interface for stream operators that can select the input to get StreamRecord.
InputSelection - org.apache.flink.streaming.api.operators中的类
Describe the input selection that stream operators want to read records.
InputSelection.Builder - org.apache.flink.streaming.api.operators中的类
Utility class for creating InputSelection.
inputSerializer - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
inputStream1 - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStream2 - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputWatermark(Watermark, int, PushingAsyncDataInput.DataOutput<?>) - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
Feed a Watermark into the valve.
inputWatermarkStatus(WatermarkStatus, int, PushingAsyncDataInput.DataOutput<?>) - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
Feed a WatermarkStatus into the valve.
INSTANCE - 类 中的静态变量org.apache.flink.streaming.runtime.io.BlockingQueueBroker
Singleton instance.
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing.functions中的类
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable and an AggregateFunction.
InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
InternalIterableAllWindowFunction<IN,OUT,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
InternalProcessAllWindowContext<IN,OUT,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing.functions中的类
Internal reusable context wrapper.
InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - org.apache.flink.streaming.api.functions.windowing中的类
Internal reusable context wrapper.
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - org.apache.flink.streaming.api.functions.windowing中的类
Internal reusable context wrapper.
InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing.functions中的类
Internal reusable context wrapper.
internalSetKeyContextElement(StreamRecord<T>, KeySelector<T, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
InternalTimer<K,N> - org.apache.flink.streaming.api.operators中的接口
Internal interface for in-flight timers.
InternalTimerService<N> - org.apache.flink.streaming.api.operators中的接口
Interface for working with time and timers.
internalTimerService - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
InternalTimerServiceImpl<K,N> - org.apache.flink.streaming.api.operators中的类
InternalTimerService that stores timers on the Java heap.
internalTimerServiceManager() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns the internal timer service manager for the stream operator.
InternalTimerServiceSerializationProxy<K> - org.apache.flink.streaming.api.operators中的类
Serialization proxy for the timer services for a given key-group.
InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, ClassLoader, int) - 类 的构造器org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
Constructor to use when restoring timer services.
InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, int) - 类 的构造器org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
Constructor to use when writing timer services.
InternalTimersSnapshot<K,N> - 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() - 类 的构造器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>>) - 类 的构造器org.apache.flink.streaming.api.operators.InternalTimersSnapshot
Constructor to use when snapshotting the timers.
InternalTimersSnapshotReaderWriters - org.apache.flink.streaming.api.operators中的类
Readers and writers for different versions of the InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters() - 类 的构造器org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> - org.apache.flink.streaming.api.operators中的接口
A reader for a InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter - org.apache.flink.streaming.api.operators中的接口
A writer for a InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> - org.apache.flink.streaming.api.operators中的类
A TypeSerializer used to serialize/deserialize a TimerHeapInternalTimer.
InternalTimeServiceManager<K> - org.apache.flink.streaming.api.operators中的接口
An entity keeping all the time-related services.
InternalTimeServiceManager.Provider - org.apache.flink.streaming.api.operators中的接口
A provider pattern for creating an instance of a InternalTimeServiceManager.
InternalTimeServiceManagerImpl<K> - org.apache.flink.streaming.api.operators中的类
An entity keeping all the time-related services.
InternalWindowFunction<IN,OUT,KEY,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing.functions中的接口
Internal interface for functions that are evaluated over keyed (grouped) windows.
InternalWindowFunction.InternalWindowContext - org.apache.flink.streaming.runtime.operators.windowing.functions中的接口
A context for InternalWindowFunction, similar to ProcessWindowFunction.Context but for internal use.
intersects(TimeWindow) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Join elements of this KeyedStream with elements of another KeyedStream over a time interval that can be specified with KeyedStream.IntervalJoin.between(Time, Time).
IntervalJoined(KeyedStream<IN1, KEY>, KeyedStream<IN2, KEY>, long, long, boolean, boolean) - 类 的构造器org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
 
IntervalJoinOperator<K,T1,T2,OUT> - org.apache.flink.streaming.api.operators.co中的类
An operator to execute time-bounded stream inner joins.
IntervalJoinOperator(long, long, boolean, boolean, TypeSerializer<T1>, TypeSerializer<T2>, ProcessJoinFunction<T1, T2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Creates a new IntervalJoinOperator.
IntervalJoinOperator.BufferEntry<T> - org.apache.flink.streaming.api.operators.co中的类
A container for elements put in the left/write buffer.
IntervalJoinOperator.BufferEntrySerializer<T> - org.apache.flink.streaming.api.operators.co中的类
A serializer for the IntervalJoinOperator.BufferEntry.
IntervalJoinOperator.BufferEntrySerializerSnapshot<T> - org.apache.flink.streaming.api.operators.co中的类
A TypeSerializerSnapshot for IntervalJoinOperator.BufferEntrySerializer.
IntervalJoinOperator.BufferSerializerConfigSnapshot<T> - org.apache.flink.streaming.api.operators.co中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by IntervalJoinOperator.BufferEntrySerializerSnapshot.
intGenerator(int, int) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
intGenerator(int, int) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
invalidate() - 类 中的方法org.apache.flink.streaming.api.datastream.CachedDataStream
Invalidate the cache intermediate result of this DataStream to release the physical resources.
invalidateClusterDataset(AbstractID) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
invoke(T) - 类 中的方法org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
invoke(IN, SinkFunction.Context) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
invoke(IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
invoke(IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
invoke(IN) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction
invoke(IN, SinkFunction.Context) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction
Writes the given value to the sink.
invoke(IN) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Write value within a transaction.
invoke(IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
This should not be implemented by subclasses.
invoke(IN, SinkFunction.Context) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
invoke(IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
Implementation of the invoke method of the SinkFunction class.
invoke(IN, SinkFunction.Context) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
invoke(IN, SinkFunction.Context) - 类 中的方法org.apache.flink.streaming.experimental.CollectSink
 
invoke() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isAcceptingMails() - 枚举 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
 
isActive() - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
isAllVerticesInSameSlotSharingGroupByDefault() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Gets whether to put all vertices into the same slot sharing group by default.
isApproximateLocalRecoveryEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether approximate local recovery is enabled.
isBasicType() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
isBroadcast() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
isBroadcast() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
isCached() - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
isCanceled() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isCanceledOrStopped() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
Checks whether the source has been canceled or stopped.
isChainable(StreamEdge, StreamGraph) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
isChainEnd() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isChainingEnabled - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
isChainingEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns whether operator chaining is enabled.
isChainingEnabled() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isChainStart() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isChangelogStateBackendEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the enable status of change log for state backend.
isChangelogStateBackendEnabled(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isChangelogStateBackendEnabled() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isCheckpointCommitted(int, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Checked the resource whether the given checkpoint was committed completely.
isCheckpointingEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Checks whether checkpointing is enabled.
isCheckpointingEnabled() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isCheckpointingEnabled() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns true if checkpointing is enabled for the running job.
isCheckpointPending() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
isCheckpointPending() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
isCheckpointPending() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
isCleanupTime(W, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Returns true if the given time is the cleanup time for the given window.
isClosed() - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
isClosed - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
isClosed() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
isClosed() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Checks if the wrapped operator has been closed.
isDefaultActionAvailable() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
isElementLate(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Decide if a record is currently late, based on current watermark and allowed lateness.
isEmpty() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
isEmpty() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
True if the queue is empty; otherwise false.
isEmpty() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
isEmpty() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Checks whether the map is empty.
isEnableCheckpointsAfterTasksFinish() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isEndOfStream(T) - 接口 中的方法org.apache.flink.streaming.util.serialization.DeserializationSchema
已过时。
Method to decide whether the element signals the end of the stream.
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
isEventTime() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns true if elements are assigned to windows based on event time, false otherwise.
isExactlyOnceCheckpointMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isExternalizedCheckpointsEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether checkpoints should be persisted externally.
isExtremal(Comparable<R>, R) - 类 中的方法org.apache.flink.streaming.api.functions.aggregation.Comparator
 
isFailing() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isFailOnCheckpointingErrors() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
isFinalState() - 枚举 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
 
isFinished() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
isFinished() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Returns whether all CheckpointCommittableManager currently hold by the collector are either committed or failed.
isFire() - 枚举 中的方法org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isForceCheckpointing() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
已过时。
This will be removed once iterations properly participate in checkpointing.
isForceCheckpointing() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Forcing checkpoints will be removed in future version.
isForceUnalignedCheckpoints() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Checks whether unaligned checkpoints are forced, despite iteration feedback.
isForceUnalignedCheckpoints() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns whether unaligned checkpoints are force-enabled.
isGraphContainingLoops() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isIdle() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
isIdle() - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
isInputFinished(int) - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
isInputSelected(int) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
Tests if the input specified by inputId is selected.
isInputTypeConfigurable() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isInputTypeConfigurable() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
If the stream operator need to be configured with the data type they will operate on.
isIterative() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isKeyType() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
isLatencyMarker() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a latency marker.
isLatencyMeasurementSetup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Indicates if latency measurement has been setup.
isLatencyMeasurementStarted() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Indicates if latency mesurement has been started.
isLegacySource() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isLegacySource() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
 
isMailboxLoopRunning() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
isMailboxLoopRunning() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isMailboxThread() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Check if the current thread is the mailbox thread.
isMailboxThread() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Check if the current thread is the mailbox thread.
isMailboxThread() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
isOne() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isOutputTypeConfigurable() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
isOutputTypeConfigurable() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isOutputTypeConfigurable() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
If the stream operator need access to the output type information at StreamGraph generation.
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
isPointwise() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
isPurge() - 枚举 中的方法org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isRecord() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a record.
isRestored() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns true if the states provided by this context are restored from a checkpoint/savepoint.
isRunning() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isSameSlotSharingGroup(StreamNode) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
isStreamSource() - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isStreamSource() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
isStreamSource() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
Is this factory for StreamSource.
isTaskDeployedAsFinished() - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
isTaskDeployedAsFinished() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
isTaskDeployedAsFinished() - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
isTerminated() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
isTerminated() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
isTerminated() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.TimerService
Returns true if the service has been shut down, false otherwise.
isTupleType() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
isTwo() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isUnalignedCheckpointsEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether unaligned checkpoints are enabled.
isUnalignedCheckpointsEnabled() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns whether unaligned checkpoints are enabled.
isUnalignedCheckpointsEnabled() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
isUsingCustomRawKeyedState() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
Indicates whether or not implementations of this class is writing to the raw keyed state streams on snapshots, using AbstractStreamOperator.snapshotState(StateSnapshotContext).
isUsingCustomRawKeyedState() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Indicates whether or not implementations of this class is writing to the raw keyed state streams on snapshots, using AbstractStreamOperatorV2.snapshotState(StateSnapshotContext).
isUsingNonBlockingInput() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isVertexNameIncludeIndexPrefix() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isWatermark() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark.
isWatermarkAligned - 类 中的变量org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
 
isWatermarkStatus() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark status.
isWindowLate(W) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Initiates an iterative part of the program that feeds back data streams.
iterate(long) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Initiates an iterative part of the program that feeds back data streams.
ITERATION_SINK_NAME_PREFIX - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraph
 
ITERATION_SOURCE_NAME_PREFIX - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraph
 
iterationIdCounter - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
IterativeStream<T> - org.apache.flink.streaming.api.datastream中的类
The iterative data stream represents the start of an iteration in a DataStream.
IterativeStream(DataStream<T>, long) - 类 的构造器org.apache.flink.streaming.api.datastream.IterativeStream
 
IterativeStream.ConnectedIterativeStreams<I,F> - org.apache.flink.streaming.api.datastream中的类
The IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming program, where the original input of the iteration and the feedback of the iteration are connected as in a ConnectedStreams.
iterator - 类 中的变量org.apache.flink.streaming.api.operators.collect.ClientAndIterator
 
iterator() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates an iterator over the entries of this map.

J

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

K

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

L

lateDataOutputTag - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
OutputTag to use for late arriving events.
LatencyMarker - org.apache.flink.streaming.runtime.streamrecord中的类
Special record type carrying a timestamp of its creation time at a source operator and the vertexId and subtask index of the operator.
LatencyMarker(long, OperatorID, int) - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
Creates a latency mark with the given timestamp.
latencyStats - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
latencyStats - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
LatencyStats - org.apache.flink.streaming.util中的类
The LatencyStats objects are used to track and report on the behavior of latencies across measurements.
LatencyStats(MetricGroup, int, int, OperatorID, LatencyStats.Granularity) - 类 的构造器org.apache.flink.streaming.util.LatencyStats
 
LatencyStats.Granularity - org.apache.flink.streaming.util中的枚举
Granularity for latency metrics.
LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
已过时。
Replaced by KeyedCoProcessOperator which takes KeyedCoProcessFunction
LegacyKeyedCoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
LegacyKeyedProcessOperator<K,IN,OUT> - org.apache.flink.streaming.api.operators中的类
已过时。
Replaced by KeyedProcessOperator which takes KeyedProcessFunction
LegacyKeyedProcessOperator(ProcessFunction<IN, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
LegacySinkTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This Transformation represents a stream Sink.
LegacySinkTransformation(Transformation<T>, String, StreamSink<T>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.LegacySinkTransformation
Creates a new LegacySinkTransformation from the given input Transformation.
LegacySinkTransformation(Transformation<T>, String, StreamOperatorFactory<Object>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
LegacySinkTransformationTranslator<IN> - org.apache.flink.streaming.runtime.translators中的类
LegacySinkTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
 
LegacySourceTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This represents a Source.
LegacySourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int, Boundedness) - 类 的构造器org.apache.flink.streaming.api.transformations.LegacySourceTransformation
Creates a new LegacySourceTransformation from the given operator.
LegacySourceTransformation(String, StreamOperatorFactory<T>, TypeInformation<T>, int, Boundedness) - 类 的构造器org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
LegacySourceTransformationTranslator<OUT> - org.apache.flink.streaming.runtime.translators中的类
LegacySourceTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
 
ListCheckpointed<T extends Serializable> - org.apache.flink.streaming.api.checkpoint中的接口
已过时。
If you need to do non-keyed state snapshots of your operator, use CheckpointedFunction. This should only be needed in rare cases, though.
listCompletedClusterDatasets() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
load(Logger) - 接口 中的静态方法org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
Loads the implementation, if it is accessible.
LocalStreamEnvironment - org.apache.flink.streaming.api.environment中的类
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
LocalStreamEnvironment() - 类 的构造器org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new mini cluster stream environment that uses the default configuration.
LocalStreamEnvironment(Configuration) - 类 的构造器org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new mini cluster stream environment that configures its local executor with the given configuration.
LOG - 类 中的静态变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
The logger used by the operator class and its subclasses.
LOG - 类 中的静态变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
The logger used by the operator class and its subclasses.
LOG - 类 中的静态变量org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 
LOG - 类 中的静态变量org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
LOG - 类 中的静态变量org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
LOG - 类 中的静态变量org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
LOG - 类 中的静态变量org.apache.flink.streaming.runtime.tasks.StreamTask
The logger used by the StreamTask and its subclasses.
LoggingHandler() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
已过时。
 
longGenerator(long, long) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
longGenerator(long, long) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
lowerBoundExclusive() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the lower bound to be exclusive.

M

MAGIC_NUMBER - 类 中的静态变量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 - 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...) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
Mail(ThrowingRunnable<? extends Exception>, int, StreamTaskActionExecutor, String, Object...) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
mailbox - 类 中的变量org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
The mailbox data-structure that manages request for special actions, like timers, checkpoints, ...
MailboxClosedException(String) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.MailboxClosedException
 
MailboxController(MailboxProcessor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
MailboxDefaultAction - org.apache.flink.streaming.runtime.tasks.mailbox中的接口
Interface for the default action that is repeatedly invoked in the mailbox-loop.
mailboxDefaultAction - 类 中的变量org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Action that is repeatedly executed if no action request is in the mailbox.
MailboxDefaultAction.Controller - 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 - org.apache.flink.streaming.runtime.tasks.mailbox中的接口
Represents the suspended state of a MailboxDefaultAction, ready to resume.
MailboxExecutorFactory - org.apache.flink.streaming.runtime.tasks.mailbox中的接口
A factory for creating mailbox executors with a given priority.
MailboxExecutorImpl - org.apache.flink.streaming.runtime.tasks.mailbox中的类
Implementation of an executor service build around a mailbox-based execution model.
MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor, MailboxProcessor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
MailboxMetricsController - org.apache.flink.streaming.runtime.tasks.mailbox中的类
Mailbox metrics controller class.
MailboxMetricsController(Histogram, Counter) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Creates instance of MailboxMetricsController with references to metrics provided as parameters.
MailboxProcessor - org.apache.flink.streaming.runtime.tasks.mailbox中的类
This class encapsulates the logic of the mailbox-based execution model.
MailboxProcessor() - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction, StreamTaskActionExecutor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor, MailboxMetricsController) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
mailboxProcessor - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
 
MailboxProcessor.MailboxController - org.apache.flink.streaming.runtime.tasks.mailbox中的类
Implementation of MailboxDefaultAction.Controller that is connected to a MailboxProcessor instance.
mainOperator - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
the main operator that consumes the input streams of this task.
mainOperatorOutput - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
mainOperatorWrapper - 类 中的变量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) - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
maintainVisibility(long, long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
 
maintainVisibility(long, long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
 
makeResultsVisible(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
map(CoMapFunction<IN1, IN2, R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Applies a Map transformation on a DataStream.
map(MapFunction<T, R>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Applies a Map transformation on a DataStream.
map1(IN1) - 接口 中的方法org.apache.flink.streaming.api.functions.co.CoMapFunction
This method is called for each element in the first of the connected streams.
map2(IN2) - 接口 中的方法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) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
markActive() - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
markActive() - 类 中的方法org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
markActive() - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
 
markAlignmentEnd() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
markAlignmentEnd(long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
markAlignmentStart(long, long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
markAlignmentStartAndEnd(long, long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
markAsTemporarilyIdle() - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Marks the source to be temporarily idle.
markCanceledOrStopped() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
Marks this source as canceled or stopped.
markCheckpointAlignedAndTransformState(InputChannelInfo, CheckpointBarrier, FunctionWithException<BarrierHandlerState, BarrierHandlerState, Exception>) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
markEnd() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
 
markEnd() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
 
markIdle() - 类 中的方法org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
markIdle() - 类 中的方法org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
markIdle() - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
 
markStart() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
 
markStart() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
 
max(int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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 - 类 中的静态变量org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
MAX_CONCURRENT_CHECKPOINTS - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
MAX_PRIORITY - 接口 中的静态变量org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
The maximal priority for mails.
MAX_SUPPORTED_INPUT_COUNT - 类 中的静态变量org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
MAX_WATERMARK - 类 中的静态变量org.apache.flink.streaming.api.watermark.Watermark
The watermark that signifies end-of-event-time.
maxBy(int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
maxTimestamp() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the largest timestamp that still belongs to this window.
maxTimestamp() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.Window
Gets the largest timestamp that still belongs to this window.
maybeInterruptOnCancel(Thread, String, Long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
maybeInterruptOnCancel(Thread, String, Long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
measureMailboxLatency() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
 
merge(Collection<W>, W) - 接口 中的方法org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner.MergeCallback
Specifies that the given windows should be merged into the result window.
merge(CommittableCollector<CommT>) - 类 中的方法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>) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet.MergeFunction
This gets called when a merge occurs.
mergedWindows - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
mergePartitionedState(StateDescriptor<S, ?>) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.OnMergeContext
 
mergePartitionedState(StateDescriptor<S, ?>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<W>, MergingWindowAssigner.MergeCallback<W>) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
Determines which windows (if any) should be merged.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - 类 中的静态方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Merge overlapping TimeWindows.
MergingWindowAssigner<T,W extends Window> - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that can merge windows.
MergingWindowAssigner() - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
 
MergingWindowAssigner.MergeCallback<W> - org.apache.flink.streaming.api.windowing.assigners中的接口
Callback to be used in MergingWindowAssigner.mergeWindows(Collection, MergeCallback) for specifying which windows should be merged.
MergingWindowSet<W extends Window> - org.apache.flink.streaming.runtime.operators.windowing中的类
Utility for keeping track of merging Windows when using a MergingWindowAssigner in a WindowOperator.
MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Restores a MergingWindowSet from the given state.
MergingWindowSet.MergeFunction<W> - org.apache.flink.streaming.runtime.operators.windowing中的接口
MergingWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
MessageAcknowledgingSourceBase<Type,UId> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MessageAcknowledgingSourceBase(TypeInformation<UId>) - 类 的构造器org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
metrics - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
Metric group for the operator.
metrics - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Metric group for the operator.
milliseconds(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of milliseconds.
min(int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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 - 类 中的静态变量org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
The minimum interval allowed between consecutive path scans.
MIN_PAUSE_BETWEEN_CHECKPOINTS - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
MIN_PRIORITY - 接口 中的静态变量org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
The minimal priority for mails.
minBy(int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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 - 类 中的变量org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
minutes(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of minutes.
MinWatermarkGauge - org.apache.flink.streaming.runtime.metrics中的类
A Gauge for exposing the minimum watermark of chosen WatermarkGauges.
MinWatermarkGauge(WatermarkGauge...) - 类 的构造器org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
 
MultiInputSortingDataInput<IN,K> - org.apache.flink.streaming.api.operators.sort中的类
An input that wraps an underlying input and sorts the incoming records.
MultiInputSortingDataInput.SelectableSortingInputs - 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> - org.apache.flink.streaming.runtime.translators中的类
MultiInputTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
 
MultipleConnectedStreams - org.apache.flink.streaming.api.datastream中的类
This is a very basic and rough stub for a class connecting multiple input DataStreams into one, using MultipleInputStreamOperator.
MultipleConnectedStreams(StreamExecutionEnvironment) - 类 的构造器org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
MultipleFuturesAvailabilityHelper - org.apache.flink.streaming.runtime.io中的类
This class is semi-thread safe.
MultipleFuturesAvailabilityHelper(int) - 类 的构造器org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
 
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId>) - 类 的构造器org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MultipleInputSelectionHandler - org.apache.flink.streaming.runtime.io中的类
This handler is mainly used for selecting the next available input index in StreamMultipleInputProcessor.
MultipleInputSelectionHandler(InputSelectable, int) - 类 的构造器org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
MultipleInputStreamOperator<OUT> - org.apache.flink.streaming.api.operators中的接口
Interface for stream operators with multiple Inputs.
MultipleInputStreamTask<OUT> - org.apache.flink.streaming.runtime.tasks中的类
A StreamTask for executing a MultipleInputStreamOperator and supporting the MultipleInputStreamOperator to select input for reading.
MultipleInputStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
MultipleInputTransformation<OUT> - org.apache.flink.streaming.api.transformations中的类
AbstractMultipleInputTransformation implementation for non-keyed streams.
MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.MultipleInputTransformation
 

N

name(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the name of this sink.
name(String) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the name of the current data stream.
NetworkInputConfig(TypeSerializer<?>, int) - 类 的构造器org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
 
NetworkInputConfig(TypeSerializer<?>, int, StreamConfig.InputRequirement) - 类 的构造器org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
 
NeverTrigger() - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
next() - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
Get next user visible result, returns null if currently there is no more.
next() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
next() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
next() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
Returns the next element of the DataStream.
nextSelection() - 类 中的方法org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
 
nextSelection() - 接口 中的方法org.apache.flink.streaming.api.operators.InputSelectable
Returns the next InputSelection that wants to get the record.
nextValue(V) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called for each value found for the current key.
NO_OP - 接口 中的静态变量org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
 
NO_RETRY_STRATEGY - 类 中的静态变量org.apache.flink.streaming.util.retryable.AsyncRetryStrategies
 
NO_VERSION - 类 中的静态变量org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
NonChainedOutput - org.apache.flink.streaming.api.graph中的类
Used by operator chain and represents a non-chained output of the corresponding stream operator.
NonChainedOutput(boolean, int, int, int, long, boolean, IntermediateDataSetID, OutputTag<?>, StreamPartitioner<?>, ResultPartitionType) - 类 的构造器org.apache.flink.streaming.api.graph.NonChainedOutput
 
NONE_AVAILABLE - 类 中的静态变量org.apache.flink.streaming.api.operators.InputSelection
 
nonParallel - 类 中的变量org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Indicate this is a non-parallel operator and cannot set a non-1 degree of parallelism
NoOpStreamOperator() - 类 的构造器org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator
 
NoOpTimestampsAndWatermarks<T> - org.apache.flink.streaming.api.operators.source中的类
An implementation of TimestampsAndWatermarks where all watermarking/event-time operations are no-ops.
NoOpTimestampsAndWatermarks(TimestampAssigner<T>) - 类 的构造器org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
Creates a new NoOpTimestampsAndWatermarks with the given TimestampAssigner.
noOutput() - 类 中的静态方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
Returns the type information for a CommittableMessage with no committable.
notifyAbort(long, CheckpointException) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
notifyAbortOnCancellationBarrier(long) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
notifyCheckpoint(CheckpointBarrier) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
notifyCheckpointAbortAsync(long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
notifyCheckpointAbortAsync(long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
notifyCheckpointAborted(long, OperatorChain<?, ?>, Supplier<Boolean>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Notified on the task side once a distributed checkpoint has been aborted.
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
 
notifyCheckpointComplete(long, OperatorChain<?, ?>, Supplier<Boolean>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Notified on the task side once a distributed checkpoint has been completed.
notifyCheckpointCompleteAsync(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyCheckpointSubsumed(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
notifyCheckpointSubsumed(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
notifyCheckpointSubsumed(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
notifyCheckpointSubsumed(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
 
notifyCheckpointSubsumed(long, OperatorChain<?, ?>, Supplier<Boolean>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Notified on the task side once a distributed checkpoint has been subsumed.
notifyCheckpointSubsumedAsync(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
notifyCheckpointSubsumedAsync(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyOfError(Throwable) - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
 
numberOfChannels - 类 中的变量org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
numEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers(N) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 
numLateRecordsDropped - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
numOperators - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
numProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers(N) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 

O

of(SerializableSupplier<SimpleVersionedSerializer<CommT>>) - 类 中的静态方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
Returns the type information based on the serializer for a CommittableMessage.
of(StreamOperator<OUT>) - 类 中的静态方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
Create a SimpleOperatorFactory from existed StreamOperator.
of(Time, Time) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.streaming.api.windowing.evictors.CountEvictor
Creates a CountEvictor that keeps the given number of elements.
of(long, boolean) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
Creates a DeltaEvictor from the given threshold and DeltaFunction.
of(double, DeltaFunction<T>, boolean) - 类 中的静态方法org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
Creates a DeltaEvictor from the given threshold, DeltaFunction.
of(Time) - 类 中的静态方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
Creates a TimeEvictor that keeps the given number of elements.
of(Time, boolean) - 类 中的静态方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
Creates a TimeEvictor that keeps the given number of elements.
of(long, TimeUnit) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time of the given duration and TimeUnit.
of(Time) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
Creates a trigger that continuously fires based on the given interval.
of(Time) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
Creates a trigger that continuously fires based on the given interval.
of(long) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
Creates a delta trigger from the given threshold and DeltaFunction.
of(Trigger<T, W>, Duration) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
Creates a new ProcessingTimeoutTrigger that fires when the inner trigger is fired or when the timeout timer fires.
of(Trigger<T, W>, Duration, boolean, boolean) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
Creates a new ProcessingTimeoutTrigger that fires when the inner trigger is fired or when the timeout timer fires.
of(Trigger<T, W>) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
Creates a new purging trigger from the given Trigger.
of(RuntimeContext) - 类 中的静态方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
Creates a CommittableCollector based on the current runtime information.
one(T1) - 类 中的静态方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
OneInputStreamOperator<IN,OUT> - org.apache.flink.streaming.api.operators中的接口
Interface for stream operators with one input.
OneInputStreamOperatorFactory<IN,OUT> - org.apache.flink.streaming.api.operators中的接口
A factory to create OneInputStreamOperator.
OneInputStreamTask<IN,OUT> - org.apache.flink.streaming.runtime.tasks中的类
OneInputStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
OneInputStreamTask(Environment, TimerService) - 类 的构造器org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
OneInputTransformation<IN,OUT> - org.apache.flink.streaming.api.transformations中的类
This Transformation represents the application of a OneInputStreamOperator to one input Transformation.
OneInputTransformation(Transformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.OneInputTransformation
Creates a new OneInputTransformation from the given input and operator.
OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.OneInputTransformation
 
OneInputTransformationTranslator<IN,OUT> - org.apache.flink.streaming.runtime.translators中的类
OneInputTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
 
onElement(IN, SinkFunction.Context) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onElement(IN, long, Long, long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onElement(IN, long, Long, long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onElement(Object, long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
 
onElement(Object, long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger
Called for every element that gets added to a pane.
onElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onEvent(T, long, WatermarkOutput) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
onEvent(T, long, WatermarkOutput) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
onEventTime(InternalTimer<KEY, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
 
onEventTime(InternalTimer<KS, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
onEventTime(InternalTimer<K, String>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
onEventTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
onEventTime(InternalTimer<K, N>) - 接口 中的方法org.apache.flink.streaming.api.operators.Triggerable
Invoked when an event-time timer fires.
onEventTime(long, GlobalWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onEventTime(long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
 
onEventTime(long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
onEventTime(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onEventTime(InternalTimer<K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
onMerge(GlobalWindow, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onMerge(W, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onMerge(TimeWindow, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onMerge(TimeWindow, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onMerge(W, Trigger.OnMergeContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger
Called when several windows have been merged into one window by the WindowAssigner.
onMerge(Collection<W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onPartFileOpened(BucketID, Path) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.FileLifeCycleListener
Notifies a new file has been opened.
onPeriodicEmit(WatermarkOutput) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
onPeriodicEmit(WatermarkOutput) - 类 中的方法org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
onProcessingTime(InternalTimer<KEY, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
 
onProcessingTime(InternalTimer<KS, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
onProcessingTime(InternalTimer<K, String>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
onProcessingTime(InternalTimer<K, N>) - 接口 中的方法org.apache.flink.streaming.api.operators.Triggerable
Invoked when a processing-time timer fires.
onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
 
onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger
Called when a processing-time timer that was set using the trigger context fires.
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
onProcessingTime(InternalTimer<K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onProcessingTime(InternalTimer<K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
onTimer(long, CoProcessFunction<IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.co.CoProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedCoProcessFunction<K, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedProcessFunction<K, I, O>.OnTimerContext, Collector<O>) - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, ProcessFunction<I, O>.OnTimerContext, Collector<O>) - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction
Called when a timer set using TimerService fires.
OnTimerContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
 
OnTimerContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
 
OnTimerContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
 
OnTimerContext() - 类 的构造器org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
 
OnTimerContext() - 类 的构造器org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
 
onWatermark(KEY, Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.OnWatermarkCallback
The action to be triggered upon reception of a watermark.
OnWatermarkCallback<KEY> - org.apache.flink.streaming.api.operators中的接口
A callback registered with the InternalWatermarkCallbackService service.
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.sink.SocketClientSink
Initialize the connection with the Socket in the server.
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
open() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
open(String, FunctionInitializationContext, RuntimeContext) - 接口 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
Open and initialize state for DataGenerator.
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
open(String, FunctionInitializationContext, RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
open(String, FunctionInitializationContext, RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
open() - 类 中的方法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. state initialization.
open() - 类 中的方法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. state initialization.
open() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.ProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamFlatMap
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
 
open() - 接口 中的方法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() - 类 中的方法org.apache.flink.streaming.api.operators.StreamProject
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSink
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.experimental.CollectSink
Initialize the connection with the Socket in the server.
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Opens/connects to the resource, and possibly creates it beforehand.
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
OperatorChain<OUT,OP extends StreamOperator<OUT>> - 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>>>) - 类 的构造器org.apache.flink.streaming.runtime.tasks.OperatorChain
 
operatorChain - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
The chain of operators executed by this task.
OperatorChain.ChainedSource - org.apache.flink.streaming.runtime.tasks中的类
Wrapper class to access the chained sources and their's outputs.
operatorEventDispatcher - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
OperatorEventDispatcherImpl - org.apache.flink.streaming.runtime.tasks中的类
An implementation of the OperatorEventDispatcher.
OperatorEventDispatcherImpl(ClassLoader, TaskOperatorEventGateway) - 类 的构造器org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
 
operatorFactory - 类 中的变量org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
operatorId - 类 中的变量org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
OperatorSnapshotFinalizer - org.apache.flink.streaming.api.operators中的类
This class finalizes OperatorSnapshotFutures.
OperatorSnapshotFinalizer(OperatorSnapshotFutures) - 类 的构造器org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
OperatorSnapshotFutures - org.apache.flink.streaming.api.operators中的类
OperatorSnapshotFutures() - 类 的构造器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>>>) - 类 的构造器org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
operatorStateBackend() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns the operator state backend for the stream operator.
operatorStateBackend(String, PrioritizedOperatorSubtaskState, CloseableRegistry) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
OrderedStreamElementQueue<OUT> - org.apache.flink.streaming.api.operators.async.queue中的类
Ordered StreamElementQueue implementation.
OrderedStreamElementQueue(int) - 类 的构造器org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator.
orderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, AsyncRetryStrategy<OUT>) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
org.apache.flink.streaming.api - 程序包 org.apache.flink.streaming.api
 
org.apache.flink.streaming.api.checkpoint - 程序包 org.apache.flink.streaming.api.checkpoint
 
org.apache.flink.streaming.api.connector.sink2 - 程序包 org.apache.flink.streaming.api.connector.sink2
 
org.apache.flink.streaming.api.datastream - 程序包 org.apache.flink.streaming.api.datastream
 
org.apache.flink.streaming.api.environment - 程序包 org.apache.flink.streaming.api.environment
 
org.apache.flink.streaming.api.functions - 程序包 org.apache.flink.streaming.api.functions
 
org.apache.flink.streaming.api.functions.aggregation - 程序包 org.apache.flink.streaming.api.functions.aggregation
 
org.apache.flink.streaming.api.functions.async - 程序包 org.apache.flink.streaming.api.functions.async
 
org.apache.flink.streaming.api.functions.co - 程序包 org.apache.flink.streaming.api.functions.co
 
org.apache.flink.streaming.api.functions.query - 程序包 org.apache.flink.streaming.api.functions.query
 
org.apache.flink.streaming.api.functions.sink - 程序包 org.apache.flink.streaming.api.functions.sink
 
org.apache.flink.streaming.api.functions.sink.filesystem - 程序包 org.apache.flink.streaming.api.functions.sink.filesystem
 
org.apache.flink.streaming.api.functions.source - 程序包 org.apache.flink.streaming.api.functions.source
 
org.apache.flink.streaming.api.functions.source.datagen - 程序包 org.apache.flink.streaming.api.functions.source.datagen
 
org.apache.flink.streaming.api.functions.timestamps - 程序包 org.apache.flink.streaming.api.functions.timestamps
 
org.apache.flink.streaming.api.functions.windowing - 程序包 org.apache.flink.streaming.api.functions.windowing
 
org.apache.flink.streaming.api.functions.windowing.delta - 程序包 org.apache.flink.streaming.api.functions.windowing.delta
 
org.apache.flink.streaming.api.functions.windowing.delta.extractor - 程序包 org.apache.flink.streaming.api.functions.windowing.delta.extractor
 
org.apache.flink.streaming.api.graph - 程序包 org.apache.flink.streaming.api.graph
 
org.apache.flink.streaming.api.operators - 程序包 org.apache.flink.streaming.api.operators
 
org.apache.flink.streaming.api.operators.async - 程序包 org.apache.flink.streaming.api.operators.async
 
org.apache.flink.streaming.api.operators.async.queue - 程序包 org.apache.flink.streaming.api.operators.async.queue
 
org.apache.flink.streaming.api.operators.co - 程序包 org.apache.flink.streaming.api.operators.co
 
org.apache.flink.streaming.api.operators.collect - 程序包 org.apache.flink.streaming.api.operators.collect
 
org.apache.flink.streaming.api.operators.sort - 程序包 org.apache.flink.streaming.api.operators.sort
 
org.apache.flink.streaming.api.operators.sorted.state - 程序包 org.apache.flink.streaming.api.operators.sorted.state
 
org.apache.flink.streaming.api.operators.source - 程序包 org.apache.flink.streaming.api.operators.source
 
org.apache.flink.streaming.api.operators.util - 程序包 org.apache.flink.streaming.api.operators.util
 
org.apache.flink.streaming.api.transformations - 程序包 org.apache.flink.streaming.api.transformations
 
org.apache.flink.streaming.api.watermark - 程序包 org.apache.flink.streaming.api.watermark
 
org.apache.flink.streaming.api.windowing.assigners - 程序包 org.apache.flink.streaming.api.windowing.assigners
 
org.apache.flink.streaming.api.windowing.evictors - 程序包 org.apache.flink.streaming.api.windowing.evictors
 
org.apache.flink.streaming.api.windowing.time - 程序包 org.apache.flink.streaming.api.windowing.time
 
org.apache.flink.streaming.api.windowing.triggers - 程序包 org.apache.flink.streaming.api.windowing.triggers
 
org.apache.flink.streaming.api.windowing.windows - 程序包 org.apache.flink.streaming.api.windowing.windows
 
org.apache.flink.streaming.experimental - 程序包 org.apache.flink.streaming.experimental
This package holds classes that are experimental.
org.apache.flink.streaming.runtime.io - 程序包 org.apache.flink.streaming.runtime.io
 
org.apache.flink.streaming.runtime.io.checkpointing - 程序包 org.apache.flink.streaming.runtime.io.checkpointing
 
org.apache.flink.streaming.runtime.io.recovery - 程序包 org.apache.flink.streaming.runtime.io.recovery
 
org.apache.flink.streaming.runtime.metrics - 程序包 org.apache.flink.streaming.runtime.metrics
 
org.apache.flink.streaming.runtime.operators - 程序包 org.apache.flink.streaming.runtime.operators
This package contains the operators that perform the stream transformations.
org.apache.flink.streaming.runtime.operators.sink - 程序包 org.apache.flink.streaming.runtime.operators.sink
 
org.apache.flink.streaming.runtime.operators.sink.committables - 程序包 org.apache.flink.streaming.runtime.operators.sink.committables
 
org.apache.flink.streaming.runtime.operators.util - 程序包 org.apache.flink.streaming.runtime.operators.util
 
org.apache.flink.streaming.runtime.operators.windowing - 程序包 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 - 程序包 org.apache.flink.streaming.runtime.operators.windowing.functions
 
org.apache.flink.streaming.runtime.partitioner - 程序包 org.apache.flink.streaming.runtime.partitioner
 
org.apache.flink.streaming.runtime.streamrecord - 程序包 org.apache.flink.streaming.runtime.streamrecord
 
org.apache.flink.streaming.runtime.tasks - 程序包 org.apache.flink.streaming.runtime.tasks
This package contains classes that realize streaming tasks.
org.apache.flink.streaming.runtime.tasks.mailbox - 程序包 org.apache.flink.streaming.runtime.tasks.mailbox
 
org.apache.flink.streaming.runtime.translators - 程序包 org.apache.flink.streaming.runtime.translators
 
org.apache.flink.streaming.runtime.watermarkstatus - 程序包 org.apache.flink.streaming.runtime.watermarkstatus
 
org.apache.flink.streaming.util - 程序包 org.apache.flink.streaming.util
 
org.apache.flink.streaming.util.functions - 程序包 org.apache.flink.streaming.util.functions
 
org.apache.flink.streaming.util.graph - 程序包 org.apache.flink.streaming.util.graph
 
org.apache.flink.streaming.util.keys - 程序包 org.apache.flink.streaming.util.keys
 
org.apache.flink.streaming.util.retryable - 程序包 org.apache.flink.streaming.util.retryable
 
org.apache.flink.streaming.util.serialization - 程序包 org.apache.flink.streaming.util.serialization
 
org.apache.flink.streaming.util.typeutils - 程序包 org.apache.flink.streaming.util.typeutils
 
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Emits a record to the side output identified by the OutputTag.
output - 类 中的变量org.apache.flink.streaming.api.operators.AbstractInput
 
output - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
output - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
Output<T> - 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) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
output(OutputTag<X>, X) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
output(OutputTag<X>, X) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
OutputFormatOperatorFactory<IN> - org.apache.flink.streaming.api.operators中的接口
Interface for operator factories which create the sink operator containing an OutputFormat.
OutputFormatSinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
OutputFormatSinkFunction(OutputFormat<IN>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
OutputTypeConfigurable<OUT> - 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 - 类 中的变量org.apache.flink.streaming.api.operators.AbstractInput
 

P

PACT - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
PARALLELISM - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
ParallelSourceFunction<OUT> - org.apache.flink.streaming.api.functions.source中的接口
A stream data source that is executed in parallel.
partitionCustom(Partitioner<K>, int) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
partitionCustom(Partitioner<K>, String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
partitionCustom(Partitioner<K>, KeySelector<T, K>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
PartitionTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This transformation represents a change of partitioning of the input elements.
PartitionTransformation(Transformation<T>, StreamPartitioner<T>) - 类 的构造器org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
PartitionTransformation(Transformation<T>, StreamPartitioner<T>, StreamExchangeMode) - 类 的构造器org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
PartitionTransformationTranslator<OUT> - org.apache.flink.streaming.runtime.translators中的类
PartitionTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
 
PassThroughAllWindowFunction<W extends Window,T> - org.apache.flink.streaming.api.functions.windowing中的类
A AllWindowFunction that just emits each input element.
PassThroughAllWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
 
PassThroughWindowFunction<K,W extends Window,T> - org.apache.flink.streaming.api.functions.windowing中的类
A WindowFunction that just emits each input element.
PassThroughWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
path - 类 中的变量org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
 
pendingCheckpoints - 类 中的变量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 - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
pendingCommitTransactions - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
pendingTransaction - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
pendingTransactions() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
PeriodTimer - org.apache.flink.streaming.runtime.tasks.mailbox中的接口
Interface for the measurement of the period of time.
persist() - 类 中的方法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) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
PhysicalTransformation<T> - org.apache.flink.streaming.api.transformations中的类
A Transformation that creates a physical operation.
pollNext() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
preCommit(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Pre commit previously created transaction.
PREDECESSORS - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?>, CloseableRegistry) - 类 中的静态方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
prepareClose() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Lifecycle method to close the mailbox for action submission.
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
 
prepareSnapshot(ChannelStateWriter, long) - 接口 中的方法org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - 接口 中的方法org.apache.flink.streaming.runtime.io.StreamTaskInput
Prepares to spill the in-flight input buffers as checkpoint snapshot.
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
prepareSnapshot(ChannelStateWriter, long) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
prepareSnapshotPreBarrier(long) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
print() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stdout).
print(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stdout).
PrintSink<IN> - org.apache.flink.streaming.api.functions.sink中的类
Sink implementation writing every element to the standard output or standard error stream.
PrintSink() - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSink
Instantiates a print sink function that prints to STDOUT.
PrintSink(boolean) - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSink
Instantiates a print sink that prints to STDOUT or STDERR.
PrintSink(String) - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSink
Instantiates a print sink that prints to STDOUT and gives a sink identifier.
PrintSink(String, boolean) - 类 的构造器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> - org.apache.flink.streaming.api.functions.sink中的类
Implementation of the SinkFunction writing every tuple to the standard output or standard error stream.
PrintSinkFunction() - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out.
PrintSinkFunction(boolean) - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out.
PrintSinkFunction(String, boolean) - 类 的构造器org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out and gives a sink identifier.
printToErr() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard error stream (stderr).
printToErr(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard error stream (stderr).
process(ProcessAllWindowFunction<T, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a KeyedStream and applies the given KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream.
process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a KeyedStream and applies the given KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream.
process(BroadcastProcessFunction<IN1, IN2, OUT>) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a non-keyed DataStream and applies the given BroadcastProcessFunction on them, thereby creating a transformed output stream.
process(BroadcastProcessFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a non-keyed DataStream and applies the given BroadcastProcessFunction on them, thereby creating a transformed output stream.
process(CoProcessFunction<IN1, IN2, R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
process(ProcessFunction<T, R>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
process(KeyedProcessFunction<KEY, T, R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Evaluates the window and outputs none or several elements.
process(ProcessWindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
ProcessAllWindowFunction<IN,OUT,W extends Window> - 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() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
 
ProcessAllWindowFunction.Context - org.apache.flink.streaming.api.functions.windowing中的类
The context holding window metadata.
processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
processBroadcastElement(IN2, BroadcastProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
This method is called for each element in the broadcast stream.
processBroadcastElement(IN2, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.Context, Collector<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
This method is called for each element in the broadcast stream.
processBuffer(BufferOrEvent) - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
processContext - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processElement(IN1, BroadcastProcessFunction<IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction
Process one element from the input stream.
processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction
Process one element from the input stream.
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
 
processElement(StreamRecord<IN>) - 接口 中的方法org.apache.flink.streaming.api.operators.Input
Processes one element that arrived on this input of the MultipleInputStreamOperator.
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.ProcessOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamFilter
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamFlatMap
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamMap
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamProject
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSink
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator
 
processElement1(IN1, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamMap
 
processElement1(StreamRecord<T1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Process a StreamRecord from the left stream.
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement1(StreamRecord<IN1>) - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
processElement1(StreamRecord<IN1>) - 接口 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamMap
 
processElement2(StreamRecord<T2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Process a StreamRecord from the right stream.
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement2(StreamRecord<IN2>) - 类 中的方法org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
已过时。
 
processElement2(StreamRecord<IN2>) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes one element that arrived on the second input of this two-input operator.
processEndOfPartition(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
processEndOfPartition(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
 
processEndOfPartition(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
processEvent(BufferOrEvent) - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
processEvent(BufferOrEvent) - 类 中的方法org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
 
ProcessFunction<I,O> - org.apache.flink.streaming.api.functions中的类
A function that processes elements of a stream.
ProcessFunction() - 类 的构造器org.apache.flink.streaming.api.functions.ProcessFunction
 
ProcessFunction.Context - org.apache.flink.streaming.api.functions中的类
ProcessFunction.OnTimerContext - org.apache.flink.streaming.api.functions中的类
Information available in an invocation of ProcessFunction.onTimer(long, OnTimerContext, Collector).
ProcessingTimeoutTrigger<T,W extends Window> - org.apache.flink.streaming.api.windowing.triggers中的类
A Trigger that can turn any Trigger into a timeout Trigger.
processingTimeService - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processingTimeService - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
processingTimeService - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
ProcessingTimeService - 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 - org.apache.flink.streaming.runtime.tasks中的接口
Interface for StreamOperatorFactory, which enables stream operators to access ProcessingTimeService.
ProcessingTimeServiceFactory - org.apache.flink.streaming.runtime.tasks中的接口
A factory for creating processing time services with a given MailboxExecutor.
ProcessingTimeServiceUtil - org.apache.flink.streaming.runtime.tasks中的类
Utility for classes that implements the ProcessingTimeService interface.
ProcessingTimeServiceUtil() - 类 的构造器org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
 
ProcessingTimeSessionWindows - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner that windows elements into sessions based on the current processing time.
ProcessingTimeSessionWindows(long) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
ProcessingTimeTrigger - 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() - 接口 中的方法org.apache.flink.streaming.runtime.io.StreamInputProcessor
In case of two and more input processors this method must call InputSelectable.nextSelection() to choose which input to consume from next.
processInput() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
processInput() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
processInput(MailboxDefaultAction.Controller) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
processInput(MailboxDefaultAction.Controller) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
processInput(MailboxDefaultAction.Controller) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
This method implements the default action of the task (e.g. processing one event from the input).
ProcessJoinFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的类
A function that processes two joined elements and produces a single output one.
ProcessJoinFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
 
ProcessJoinFunction.Context - org.apache.flink.streaming.api.functions.co中的类
The context that is available during an invocation of ProcessJoinFunction.processElement(Object, Object, Context, Collector).
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractInput
 
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.Input
Processes a LatencyMarker that arrived on the first input of this two-input operator.
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
processLatencyMarker1(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker1(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a LatencyMarker that arrived on the first input of this two-input operator.
processLatencyMarker2(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker2(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a LatencyMarker that arrived on the second input of this two-input operator.
ProcessOperator<IN,OUT> - org.apache.flink.streaming.api.operators中的类
ProcessOperator(ProcessFunction<IN, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.ProcessOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractInput
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.Input
Processes a Watermark that arrived on the first input of this two-input operator.
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.ProcessOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSink
 
processWatermark(Watermark) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
processWatermark1(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark1(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a Watermark that arrived on the first input of this two-input operator.
processWatermark2(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark2(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a Watermark that arrived on the second input of this two-input operator.
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractInput
 
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermarkStatus(WatermarkStatus, int) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
processWatermarkStatus(WatermarkStatus) - 接口 中的方法org.apache.flink.streaming.api.operators.Input
Processes a WatermarkStatus that arrived on this input of the MultipleInputStreamOperator.
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
Override the base implementation to completely ignore statuses propagated from upstream.
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
processWatermarkStatus1(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermarkStatus1(WatermarkStatus) - 接口 中的方法org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a WatermarkStatus that arrived on the first input of this two-input operator.
processWatermarkStatus2(WatermarkStatus) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermarkStatus2(WatermarkStatus) - 接口 中的方法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> - 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() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
 
ProcessWindowFunction.Context - org.apache.flink.streaming.api.functions.windowing中的类
The context holding window metadata.
ProgressiveTimestampsAndWatermarks<T> - 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) - 类 的构造器org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
 
project(int...) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Initiates a Project transformation on a Tuple DataStream.
projectTuple1() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple10() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple11() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple12() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple13() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple14() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple15() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple16() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple17() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple18() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple19() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple2() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple20() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple21() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple22() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple23() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple24() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple25() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple3() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple4() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple5() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple6() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple7() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple8() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple9() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTupleX() - 类 中的方法org.apache.flink.streaming.api.datastream.StreamProjection
Chooses a projectTupleX according to the length of StreamProjection.fieldIndexes.
Provider(OperatorID, int) - 类 的构造器org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
PurgingTrigger<T,W extends Window> - org.apache.flink.streaming.api.windowing.triggers中的类
A trigger that can turn any Trigger into a purging Trigger.
PushingAsyncDataInput<T> - 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> - org.apache.flink.streaming.runtime.io中的接口
Basic data output interface used in emitting the next element from data input.
put(K, V) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts the given value, mapped under the given key.
put(Mail) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
putFirst(Mail) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Adds the given action to the head of the mailbox.
putFirst(Mail) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
putIfAbsent(K, KeyMap.LazyFactory<V>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts or aggregates a value into the hash map.

Q

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

R

random - 类 中的变量org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
RandomGenerator<T> - org.apache.flink.streaming.api.functions.source.datagen中的类
Random generator.
RandomGenerator() - 类 的构造器org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
rawKeyedStateInputs() - 接口 中的方法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>>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
rawOperatorStateInputs() - 接口 中的方法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>>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
read(DataInputView, boolean) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
readFile(FileInputFormat<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simple TextLineInputFormat:

 FileSource<String> source =
        FileSource.forRecordStreamFormat(
           new TextLineInputFormat(), new Path("/foo/bar"))
        .build();
 
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileInputFormat.setFilesFilter(FilePathFilter) to set a filter and StreamExecutionEnvironment.readFile(FileInputFormat, String, FileProcessingMode, long)
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simple TextLineInputFormat:

 FileSource<String> source =
        FileSource.forRecordStreamFormat(
           new TextLineInputFormat(), new Path("/foo/bar"))
        .monitorContinuously(Duration.of(10, SECONDS))
        .build();
 
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simple TextLineInputFormat:

 FileSource<String> source =
        FileSource.forRecordStreamFormat(
           new TextLineInputFormat(), new Path("/foo/bar"))
        .monitorContinuously(Duration.of(10, SECONDS))
        .build();
 
readFileStream(String, long, FileMonitoringFunction.WatchType) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
ReadOnlyContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
 
ReadOnlyContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.ReadOnlyContext
 
ReadOnlyContext() - 类 的构造器org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
 
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
readTextFile(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simple TextLineInputFormat:

 FileSource<String> source =
        FileSource.forRecordStreamFormat(
           new TextLineInputFormat(), new Path("/foo/bar"))
        .build();
 
readTextFile(String, String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
Use FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simple TextLineInputFormat:

 FileSource<String> source =
        FileSource.forRecordStreamFormat(
         new TextLineInputFormat("UTF-8"), new Path("/foo/bar"))
        .build();
 
readTimersSnapshot(DataInputView) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
Reads a timers snapshot from the provided input view.
readVersionAndDeserializeList(SimpleVersionedSerializer<T>, DataInputView) - 类 中的静态方法org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
 
rebalance() - 类 中的方法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> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that distributes the data equally by cycling through the output channels.
RebalancePartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
recordDeserializers - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
recordWriter - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
 
RecordWriterOutput<OUT> - org.apache.flink.streaming.runtime.io中的类
Implementation of Output that sends data using a RecordWriter.
RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, boolean) - 类 的构造器org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
RecoverableStreamTaskInput<T> - org.apache.flink.streaming.runtime.io中的接口
A StreamTaskInput used during recovery of in-flight data.
recoverAndAbort(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction that was rejected by a coordinator after a failure.
recoverAndCommit(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Invoked on recovered transactions after a failure.
reduce(ReduceFunction<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(T, T) - 类 中的方法org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
reduce(T, T) - 类 中的方法org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
ReduceApplyAllWindowFunction<W extends Window,T,R> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - org.apache.flink.streaming.api.functions.windowing中的类
Internal ProcessAllWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - org.apache.flink.streaming.api.functions.windowing中的类
Internal ProcessWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
ReduceApplyWindowFunction<K,W extends Window,T,R> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
ReduceTransformation<IN,K> - 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>) - 类 的构造器org.apache.flink.streaming.api.transformations.ReduceTransformation
 
ReduceTransformationTranslator<IN,KEY> - org.apache.flink.streaming.runtime.translators中的类
ReduceTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
 
registerCachedFile(String, String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCacheTransformation(AbstractID, CacheTransformation<T>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
registerCleanupTimer(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Registers a timer to cleanup the content of the window.
registerCollectIterator(CollectResultIterator<?>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
registerCounterOnOutput(Output<StreamRecord<OUT>>, OperatorMetricGroup) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
registerEventHandler(OperatorID, OperatorEventHandler) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
 
registerEventTimeTimer(N, long) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Registers a timer to be fired when event time watermark passes the given time.
registerEventTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
registerEventTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
registerEventTimeTimer(long) - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
registerEventTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.TimerService
Registers a timer to be fired when the event time watermark passes the given time.
registerEventTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Register an event-time callback.
registerEventTimeTimer(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerExpandedSinks(Collection<Integer>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Register expanded sink nodes.
registerJobListener(JobListener) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Register a JobListener in this environment.
registerJobStatusHook(JobStatusHook) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Registers the JobStatusHook.
registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
registerProcessingTimeTimer(N, long) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimerService
Registers a timer to be fired when processing time passes the given time.
registerProcessingTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
registerProcessingTimeTimer(N, long) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
registerProcessingTimeTimer(long) - 类 中的方法org.apache.flink.streaming.api.SimpleTimerService
 
registerProcessingTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.TimerService
Registers a timer to be fired when processing time passes the given time.
registerProcessingTimeTimer(long) - 接口 中的方法org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Register a system time callback.
registerProcessingTimeTimer(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerSlotSharingGroup(SlotSharingGroup) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Register a slot sharing group with its resource spec.
registerTask(Callable<?>, Duration) - 接口 中的方法org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.DelayableTimer
Register a task to be executed some time later.
registerTimer(long, ProcessingTimeService.ProcessingTimeCallback) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
registerType(Class<?>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers the given type with the serialization stack.
registerTypeWithKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - 类 中的方法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>> - org.apache.flink.streaming.runtime.tasks中的类
A regular non finished on restore OperatorChain.
RegularOperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - 类 的构造器org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
Reinterprets the given DataStream as a KeyedStream, which extracts keys with the given KeySelector.
reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>, TypeInformation<K>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
Reinterprets the given DataStream as a KeyedStream, which extracts keys with the given KeySelector.
releaseDeserializer(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
 
RemoteStreamEnvironment - org.apache.flink.streaming.api.environment中的类
A StreamExecutionEnvironment for executing on a cluster.
RemoteStreamEnvironment(String, int, String...) - 类 的构造器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...) - 类 的构造器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[]) - 类 的构造器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) - 类 的构造器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) - 类 的构造器org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
remove() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
 
replace(X) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Replace the currently stored value by the given new value.
replace(X, long) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.util.LatencyStats
 
reportOrForwardLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
reportOrForwardLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
reportOrForwardLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSink
 
reportThrowable(Throwable) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Reports a throwable for rethrowing from the mailbox thread.
reportWatermark(Watermark, int) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
requiresSorting(StreamConfig.InputConfig) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamConfig
 
rescale() - 类 中的方法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> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that distributes the data equally by cycling through the output channels.
RescalePartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
RescalingStreamTaskNetworkInput<T> - org.apache.flink.streaming.runtime.io.recovery中的类
A StreamTaskNetworkInput implementation that demultiplexes virtual channels.
RescalingStreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo) - 类 的构造器org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
 
reset() - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
Clear the whole buffer and discard all results.
resetAlignment() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
 
resetContextEnvironment() - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
resetParameters() - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
Statements to be executed after writing a batch goes here.
resetParameters() - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
已过时。
 
resetSplitState() - 接口 中的方法org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
Sets the state of the split to null.
resetToCheckpoint(long, byte[]) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
resetToUnAvailable() - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
 
resolveCheckpoint(String) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
 
resolveOuterSchemaCompatibility(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<CoGroupedStreams.TaggedUnion<T1, T2>>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<IntervalJoinOperator.BufferEntry<T>>) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<TimerHeapInternalTimer<K, N>>) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<StreamElement>) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
已过时。
 
restore() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
 
restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
 
restoreFunctionState(StateInitializationContext, Function) - 类 中的静态方法org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
restoreState(List<T>) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.ListCheckpointed
已过时。
Restores the state of the function or operator to that of a previous checkpoint.
restoreTimersForKeyGroup(InternalTimersSnapshot<?, ?>, int) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Restore the timers (both processing and event time ones) for a given keyGroupIdx.
ResultFuture<OUT> - org.apache.flink.streaming.api.functions.async中的接口
ResultFuture collects data / error in user codes while processing async i/o.
resultPredicate() - 接口 中的方法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() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Suspension
Resume execution of the default action.
resumeConsumption(InputChannelInfo) - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
retireWindow(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Removes the given window from the set of in-flight windows.
retryLater() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
RetryPredicates - org.apache.flink.streaming.util.retryable中的类
Utility class to create concrete retry predicates.
RetryPredicates() - 类 的构造器org.apache.flink.streaming.util.retryable.RetryPredicates
 
returns(Class<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
returns(TypeHint<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
revert(long) - 类 中的方法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> - org.apache.flink.streaming.api.functions.windowing中的类
A RichFunction version of AllWindowFunction.
RichAllWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
 
RichAsyncFunction<IN,OUT> - org.apache.flink.streaming.api.functions.async中的类
Rich variant of the AsyncFunction.
RichAsyncFunction() - 类 的构造器org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
RichCoFlatMapFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的类
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
RichCoFlatMapFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
 
RichCoMapFunction<IN1,IN2,OUT> - org.apache.flink.streaming.api.functions.co中的类
A RichCoMapFunction represents a Map transformation with two different input types.
RichCoMapFunction() - 类 的构造器org.apache.flink.streaming.api.functions.co.RichCoMapFunction
 
RichParallelSourceFunction<OUT> - org.apache.flink.streaming.api.functions.source中的类
Base class for implementing a parallel data source.
RichParallelSourceFunction() - 类 的构造器org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction
 
RichProcessAllWindowFunction<IN,OUT,W extends Window> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
RichProcessAllWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
已过时。
 
RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
RichProcessWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
已过时。
 
RichSinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的类
A RichFunction version of SinkFunction.
RichSinkFunction() - 类 的构造器org.apache.flink.streaming.api.functions.sink.RichSinkFunction
 
RichSourceFunction<OUT> - 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() - 类 的构造器org.apache.flink.streaming.api.functions.source.RichSourceFunction
 
RichWindowFunction<IN,OUT,KEY,W extends Window> - org.apache.flink.streaming.api.functions.windowing中的类
Rich variant of the WindowFunction.
RichWindowFunction() - 类 的构造器org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
 
RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>, RollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
run(SourceFunction.SourceContext<T>) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - 类 中的方法org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
已过时。
 
run(SourceFunction.SourceContext<T>) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
run(SourceFunction.SourceContext<T>) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
run(SourceFunction.SourceContext<T>) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
run(SourceFunction.SourceContext<OUT>) - 类 中的方法org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
run(SourceFunction.SourceContext<String>) - 类 中的方法org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
run(SourceFunction.SourceContext<T>) - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction
Starts the source.
run(SourceFunction.SourceContext<Long>) - 类 中的方法org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
run(Object, OperatorChain<?, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
run(Object, Output<StreamRecord<OUT>>, OperatorChain<?, ?>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
run(RunnableWithException) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
run(RunnableWithException) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
已过时。
 
runDefaultAction(MailboxDefaultAction.Controller) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction
This method implements the default action of the mailbox loop (e.g. processing one event from the input).
runExclusively(Runnable) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Runs the given code exclusively on this mailbox.
runExclusively(Runnable) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
runMailboxLoop() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Runs the mailbox processing loop.
runMailboxLoop() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
runMailboxStep() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Execute a single (as small as possible) step of the mailbox.
runMailboxStep() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
runThrowing(ThrowingRunnable<E>) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
runThrowing(ThrowingRunnable<E>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
已过时。
 

S

savepoint() - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
ScalaProductFieldAccessorFactory - org.apache.flink.streaming.util.typeutils中的接口
Interface to interact with optional Scala field accessors.
scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed repeatedly at a fixed rate.
scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed repeatedly with a fixed delay.
scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
SECOND - 类 中的静态变量org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select the second input.
seconds(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of seconds.
select(int) - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection.Builder
Selects an input identified by the given inputId.
SelectableSortingInputs(StreamTaskInput<?>[], StreamTaskInput<?>[], InputSelectable) - 类 的构造器org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法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>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
self() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
已过时。
 
sendAcknowledgeCheckpointEvent(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
sendValues(Iterable<IN>, long, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
Write the given element into the backend.
SequenceGenerator<T> - 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) - 类 的构造器org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
Creates a DataGenerator that emits all numbers from the given interval exactly once.
SerializationSchema<T> - org.apache.flink.streaming.util.serialization中的接口
已过时。
Use SerializationSchema instead.
serialize(CommittableMessage<CommT>) - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
 
serialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
serialize(IntervalJoinOperator.BufferEntry<T>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
serialize(DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
serialize(DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
serialize(GlobalWindow, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
serialize(TimeWindow, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
serialize(CommittableCollector<CommT>) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
 
serialize(StreamElement, DataOutputView) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
serialize(T) - 接口 中的方法org.apache.flink.streaming.util.serialization.SerializationSchema
已过时。
Serializes the incoming element to a specified type.
serializeAccumulatorResult(long, String, long, List<byte[]>) - 类 中的静态方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
serializeAllConfigs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
Serialize all object configs synchronously.
SERIALIZEDUDF - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamConfig
 
Serializer() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
Serializer() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
serializer - 类 中的变量org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
sessionIds - 类 中的变量org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
sessionIdsPerSnapshot - 类 中的变量org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
sessionTimeout - 类 中的变量org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
sessionTimeout - 类 中的变量org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
sessionWindowTimeGapExtractor - 类 中的变量org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
sessionWindowTimeGapExtractor - 类 中的变量org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
SessionWindowTimeGapExtractor<T> - org.apache.flink.streaming.api.windowing.assigners中的接口
A SessionWindowTimeGapExtractor extracts session time gaps for Dynamic Session Window Assigners.
set(T, F) - 类 中的方法org.apache.flink.streaming.util.typeutils.FieldAccessor
Sets the field (specified in the constructor) of the given record to the given value.
setAbsoluteTimestamp(long) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
setAlignedCheckpointTimeout(Duration) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
setAlignedCheckpointTimeout(Duration) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setAlignmentTimeout(Duration) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
setAllVerticesInSameSlotSharingGroupByDefault(boolean) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setBoundedness(Boundedness) - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
Mutable for legacy sources in the Table API.
setBucketLifeCycleListener(BucketLifeCycleListener<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
setBufferTimeout(long) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the buffering timeout for data produced by this operation.
setBufferTimeout(long) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
setBufferTimeout(long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
setBufferTimeout(Integer, long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setBufferTimeout(Long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setCached(boolean) - 类 中的方法org.apache.flink.streaming.api.transformations.CacheTransformation
 
setChainedOutputs(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setChainEnd() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setChainIndex(int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setChaining(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setChaining(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
setChainingStrategy(ChainingStrategy) - 接口 中的方法org.apache.flink.streaming.api.operators.SetupableStreamOperator
已过时。
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setChainingStrategy(ChainingStrategy) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
Set the chaining strategy for operator factory.
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.PhysicalTransformation
Sets the chaining strategy of this Transformation.
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.ReduceTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setChainStart() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setChangelogStateBackendEnabled(TernaryBoolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setChangelogStateBackendEnabled(TernaryBoolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setChangelogStateBackendEnabled(TernaryBoolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setCheckpointIdOfIgnoredInFlightData(long) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setCheckpointingMode(CheckpointingMode) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the checkpointing mode (exactly-once vs. at-least-once).
setCheckpointInterval(long) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the interval in which checkpoints are periodically scheduled.
setCheckpointMode(CheckpointingMode) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setCheckpointStorage(CheckpointStorage) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
CheckpointStorage defines how StateBackend's checkpoint their state for fault tolerance in streaming applications.
setCheckpointStorage(String) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Configures the application to write out checkpoint snapshots to the configured directory.
setCheckpointStorage(URI) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Configures the application to write out checkpoint snapshots to the configured directory.
setCheckpointStorage(Path) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Configures the application to write out checkpoint snapshots to the configured directory.
setCheckpointStorage(CheckpointStorage) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setCheckpointStorage(CheckpointStorage) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setCheckpointTimeout(long) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the maximum time that a checkpoint may take before being discarded.
setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
Sets the checkpoint trigger through which the source can trigger the checkpoint.
setCoLocationGroup(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setCommitterUidHash(String) - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
Sets the uid hash of the committer operator used to recover state.
setConnectionType(StreamPartitioner<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Internal function for setting the partitioner for the DataStream.
setConnectionType(StreamPartitioner<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
 
setConsumeClusterDatasetId(IntermediateDataSetID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setContext(Optional<CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setCoordinatorListeningID(String) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
setCoordinatorListeningID(String) - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
setCurrentKey(Object) - 接口 中的方法org.apache.flink.streaming.api.operators.KeyContext
 
setCurrentKey(K) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
 
setCurrentKey(K) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
setCurrentTime(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
setCurrentWatermark(long) - 类 中的方法org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
setDefaultBufferTimeout(long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setDefaultLocalParallelism(int) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
setDefaultSavepointDirectory(String) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the description for this sink.
setDescription(String) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the description for this operation.
setEnableCheckpointsAfterTasksFinish(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setEventTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setExternalizedCheckpointCleanup(CheckpointConfig.ExternalizedCheckpointCleanup) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the mode for externalized checkpoint clean-up.
setFailOnCheckpointingErrors(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
setFileLifeCycleListener(FileLifeCycleListener<BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
setForceCheckpointing(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
已过时。
This will be removed once iterations properly participate in checkpointing.
setForceUnalignedCheckpoints(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Checks whether unaligned checkpoints are forced, despite currently non-checkpointable iteration feedback or custom partitioners.
setGlobalCommitterUidHash(String) - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
Sets the uid hash of the global committer operator used to recover state.
setGlobalStreamExchangeMode(GlobalStreamExchangeMode) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setGraphContainingLoops(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setInPhysicalEdges(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setInputFormat(Integer, InputFormat<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setInputFormat(InputFormat<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setInputs(StreamConfig.InputConfig...) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setInputType(TypeInformation<?>, ExecutionConfig) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
setInternalIndex(int) - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
setIterationId(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setIterationWaitTime(long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setJobClient(JobClient) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
setJobClient(JobClient) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
setJobId(String) - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Internally used to set the job ID after instantiation.
setJobName(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setJobType(JobType) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setKeyContextElement(StreamRecord) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractInput
 
setKeyContextElement(StreamRecord<IN>) - 接口 中的方法org.apache.flink.streaming.api.operators.Input
Set the correct key context before processing the record.
setKeyContextElement(StreamRecord<IN>) - 接口 中的方法org.apache.flink.streaming.api.operators.OneInputStreamOperator
 
setKeyContextElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
 
setKeyContextElement1(StreamRecord) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setKeyContextElement1(StreamRecord<?>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
setKeyContextElement1(StreamRecord<?>) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
setKeyContextElement2(StreamRecord) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setKeyContextElement2(StreamRecord<?>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
setKeyContextElement2(StreamRecord<?>) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeyedStateStore(KeyedStateStore) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
setKeySerializerSnapshot(TypeSerializerSnapshot<K>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setLatencyMeasurementInterval(int) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
 
setMailboxExecutor(MailboxExecutor) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
setMailboxExecutor(MailboxExecutor) - 接口 中的方法org.apache.flink.streaming.api.operators.YieldingOperatorFactory
 
setManagedMemoryFractionOperatorOfUseCase(ManagedMemoryUseCase, double) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setManagedMemoryUseCaseWeights(Map<ManagedMemoryUseCase, Integer>, Set<ManagedMemoryUseCase>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setMaxConcurrentCheckpoints(int) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
setMaxParallelism(int) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the maximum parallelism of this operator.
setMaxParallelism(int) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setMinPauseBetweenCheckpoints(long) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the minimal pause between checkpointing attempts.
setMultipleInputStateKey(Integer, List<KeySelector<?, ?>>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setNumberOfExecutionRetries(int) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
This method will be replaced by StreamExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.fixedDelayRestart(int, Time) contains the number of execution retries.
setNumberOfNetworkInputs(int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setNumberOfOutputs(int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setOperatorDescription(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setOperatorEventGateway(OperatorEventGateway) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
setOperatorID(OperatorID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOperatorId(String) - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Internally used to set the operator ID after instantiation.
setOperatorName(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOperatorNonChainedOutputs(List<NonChainedOutput>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
Sets the operator level non-chained outputs.
setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setOutputFormat(Integer, OutputFormat<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setOutputFormat(OutputFormat<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
setOutputType(TypeInformation<T>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
Set element type and re-serialize element if required.
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorFactory
setOutputType(Function, TypeInformation<T>, ExecutionConfig) - 类 中的静态方法org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
setParallelism(int) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the parallelism for this sink.
setParallelism(int) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSource
 
setParallelism(int) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism for this operator.
setParallelism(int) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the parallelism for operations executed through this environment.
setParallelism(Integer, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setParallelism(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setPartitioner(StreamPartitioner<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
setPendingCommitTransactions(List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setPendingTransaction(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setProcessingTimeService(ProcessingTimeService) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
已过时。
The ProcessingTimeService instance should be passed by the operator constructor and this method will be removed along with SetupableStreamOperator.
setProcessingTimeService(ProcessingTimeService) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
setProcessingTimeService(ProcessingTimeService) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware
 
setProcessingTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setResources(int, ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setResources(ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the restart strategy configuration.
setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
setRuntimeMode(RuntimeExecutionMode) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the runtime execution mode for the application (see RuntimeExecutionMode).
setSavepointDir(Path) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setSavepointDir(Path) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setSavepointDirectory(Path) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSavepointRestoreSettings(SavepointRestoreSettings) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSavepointRestoreSettings(SavepointRestoreSettings) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setSerializerOut(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSerializersIn(TypeSerializer<?>...) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSlotSharingGroup(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSlotSharingGroupResource(Map<String, ResourceProfile>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSlotSharingGroupResource(Map<String, ResourceProfile>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
Specify fine-grained resource requirements for slot sharing groups.
setSplitState(Serializable) - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Sets the state of the split.
setSplitState(Serializable) - 接口 中的方法org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
Sets the state of the split.
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the state backend that describes how to store operator.
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setStateBackendUsesManagedMemory(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStateKeySelector(KeySelector<T, ?>) - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
Sets the KeySelector that must be used for partitioning keyed state of this Sink.
setStateKeySelector(KeySelector<IN, ?>) - 类 中的方法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, ?>) - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Sets the KeySelectors that must be used for partitioning keyed state of this transformation.
setStateKeySerializer(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStateKeySerializer(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setStateKeyType(TypeInformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.LegacySinkTransformation
 
setStateKeyType(TypeInformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setStateKeyType(TypeInformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setStatePartitioner(int, KeySelector<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStatePartitioners(KeySelector<?, ?>...) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setStreamOperator(StreamOperator<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStreamOperatorFactory(StreamOperatorFactory<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStreamTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
In Flink 1.12 the default stream time characteristic has been changed to TimeCharacteristic.EventTime, thus you don't need to call this method for enabling event-time support anymore. Explicitly using processing-time windows and timers works in event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long). If you are using TimeCharacteristic.IngestionTime, please manually set an appropriate WatermarkStrategy. If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time) that change behaviour based on the time characteristic, please use equivalent operations that explicitly specify processing time or event time.
setSupportsUnalignedCheckpoints(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
setSynchronousSavepoint(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
setTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setTimerServiceProvider(InternalTimeServiceManager.Provider) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTimerServiceProvider(InternalTimeServiceManager.Provider) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setTimestamp(StreamRecord<?>) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
setTimestamp(long) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
setTolerableCheckpointFailureNumber(int) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Sets the transaction timeout.
setTransformationUID(Integer, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setTypeSerializerOut(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setUidHash(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets an user provided hash for this operator.
setUidHash(String) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets an user provided hash for this operator.
setUnalignedCheckpointsEnabled(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - 接口 中的方法org.apache.flink.streaming.api.operators.SetupableStreamOperator
已过时。
Initializes the operator.
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
setup(int) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
setup(int) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
SetupableStreamOperator<OUT> - org.apache.flink.streaming.api.operators中的接口
已过时。
This class is deprecated in favour of using StreamOperatorFactory and it's StreamOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<OUT>) and passing the required parameters to the Operator's constructor in create method.
setupLatencyMeasurement(TimerService, MailboxExecutor) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Sets up latency measurement with required TimerService and MailboxExecutor.
setupNetworkInputs(TypeSerializer<?>...) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setupNumRecordsInCounter(StreamOperator) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setUserHash(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setVertexDescriptionMode(PipelineOptions.VertexDescriptionMode) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setVertexID(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setVertexNameIncludeIndexPrefix(boolean) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setVertexNonChainedOutputs(List<NonChainedOutput>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
Sets the job vertex level non-chained outputs.
setWriterUidHash(String) - 类 中的方法org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
Sets the uid hash of the writer operator used to recover state.
SHIP_STRATEGY - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
shortGenerator(short, short) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
shortGenerator(short, short) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
shuffle() - 类 中的方法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> - org.apache.flink.streaming.runtime.partitioner中的类
Partitioner that distributes the data equally by selecting one output channel randomly.
ShufflePartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
shutdownService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownService() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.TimerService
Shuts down and clean up the timer service provider hard and immediately.
shutdownServiceUninterruptible(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownServiceUninterruptible(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownServiceUninterruptible(long) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.TimerService
Shuts down and clean up the timer service provider hard and immediately.
SIDE - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
sideOutput(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Write skipped late arriving element to SideOutput.
SideOutputDataStream<T> - org.apache.flink.streaming.api.datastream中的类
A SideOutputDataStream represents a DataStream that contains elements that are emitted from upstream into a side output with some tag.
SideOutputDataStream(StreamExecutionEnvironment, SideOutputTransformation<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.SideOutputDataStream
Creates a new SideOutputDataStream in the given execution environment.
sideOutputLateData(OutputTag<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
SideOutputTransformation<T> - 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>) - 类 的构造器org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
SideOutputTransformationTranslator<OUT> - org.apache.flink.streaming.runtime.translators中的类
SideOutputTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
 
signalAlreadyCommitted() - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
signalFailedWithKnownReason(Throwable) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
signalFailedWithUnknownReason(Throwable) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
SimpleInputFormatOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的类
Input format source operator factory which just wrap existed StreamSource.
SimpleInputFormatOperatorFactory(StreamSource<OUT, InputFormatSourceFunction<OUT>>) - 类 的构造器org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
 
SimpleOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的类
Simple factory which just wrap existed StreamOperator.
SimpleOperatorFactory(StreamOperator<OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
SimpleOutputFormatOperatorFactory<IN> - org.apache.flink.streaming.api.operators中的类
A simple operator factory which create StreamSink containing an OutputFormat.
SimpleOutputFormatOperatorFactory(StreamSink<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
 
SimpleStringSchema - org.apache.flink.streaming.util.serialization中的类
已过时。
Use SimpleStringSchema instead.
SimpleStringSchema() - 类 的构造器org.apache.flink.streaming.util.serialization.SimpleStringSchema
已过时。
 
SimpleStringSchema(Charset) - 类 的构造器org.apache.flink.streaming.util.serialization.SimpleStringSchema
已过时。
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
SimpleTimerService - org.apache.flink.streaming.api中的类
Implementation of TimerService that uses a InternalTimerService.
SimpleTimerService(InternalTimerService<VoidNamespace>) - 类 的构造器org.apache.flink.streaming.api.SimpleTimerService
 
SimpleTransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - 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() - 类 的构造器org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
 
SimpleUdfStreamOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的类
Udf stream operator factory which just wrap existed AbstractUdfStreamOperator.
SimpleUdfStreamOperatorFactory(AbstractUdfStreamOperator<OUT, ?>) - 类 的构造器org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
SimpleVersionedListState<T> - org.apache.flink.streaming.api.operators.util中的类
A ListState that uses a SimpleVersionedSerializer instead of a TypeSerializer.
SimpleVersionedListState(ListState<byte[]>, SimpleVersionedSerializer<T>) - 类 的构造器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 - 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> - 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>) - 类 的构造器org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
SinkContextUtil - org.apache.flink.streaming.api.functions.sink中的类
Utility for creating Sink Contexts.
SinkContextUtil() - 类 的构造器org.apache.flink.streaming.api.functions.sink.SinkContextUtil
 
SinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的接口
Interface for implementing user defined sink functionality.
SinkFunction.Context - org.apache.flink.streaming.api.functions.sink中的接口
Context that SinkFunctions can use for getting additional data about an input record.
SinkOperatorUidHashesBuilder() - 类 的构造器org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
 
sinkRestarted(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
 
sinkRestarted(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
 
sinkRestarted(long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
 
sinkTo(Sink<T, ?, ?, ?>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Adds the given Sink to this DataStream.
sinkTo(Sink<T, ?, ?, ?>, CustomSinkOperatorUidHashes) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Adds the given Sink to this DataStream.
sinkTo(Sink<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Adds the given Sink to this DataStream.
sinkTo(Sink<T>, CustomSinkOperatorUidHashes) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Adds the given Sink to this DataStream.
SinkTransformation<InputT,OutputT> - org.apache.flink.streaming.api.transformations中的类
A Transformation for Sink.
SinkTransformation(DataStream<InputT>, Sink<InputT>, TypeInformation<OutputT>, String, int, CustomSinkOperatorUidHashes) - 类 的构造器org.apache.flink.streaming.api.transformations.SinkTransformation
 
SinkTransformationTranslator<Input,Output> - org.apache.flink.streaming.runtime.translators中的类
SinkTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
 
SinkV1Adapter<InputT,CommT,WriterStateT,GlobalCommT> - org.apache.flink.streaming.api.transformations中的类
Translates Sink V1 into Sink V2.
SinkV1Adapter.GlobalCommitterAdapter - org.apache.flink.streaming.api.transformations中的类
Simulate the global committer behaviour with a committer.
SinkV1CommittableDeserializer - 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. 1.13, 1.14).
SinkV1CommittableDeserializer() - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
 
SinkWriterOperatorFactory<InputT,CommT> - org.apache.flink.streaming.runtime.operators.sink中的类
A StreamOperatorFactory for SinkWriterOperator.
SinkWriterOperatorFactory(Sink<InputT>) - 类 的构造器org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
 
size() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
size() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Return the size of the queue.
size() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
size() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the number of elements currently in the map.
size() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns the current number of mails in this mailbox.
size() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
SlidingEventTimeWindows - 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) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
SlidingProcessingTimeWindows - 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) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the slot sharing group of this operation.
slotSharingGroup(SlotSharingGroup) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the slot sharing group of this operation.
slotSharingGroup(String) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the slot sharing group of this operation.
slotSharingGroup(SlotSharingGroup) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the slot sharing group of this operation.
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
 
snapshotChannelStates(StreamOperator<?>, ChannelStateWriter.ChannelStateWriteResult, OperatorSnapshotFutures) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - 类 中的静态方法org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
snapshotState(FunctionSnapshotContext) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
This method is called when a snapshot for a checkpoint is requested.
snapshotState(long, long) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.ListCheckpointed
已过时。
Gets the current state of the function.
snapshotState(long, ListState<byte[]>, ListState<Long>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
 
snapshotState(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
snapshotState(FunctionSnapshotContext) - 接口 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
Snapshot state for DataGenerator.
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
snapshotState(StateSnapshotContext) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
snapshotState(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
Called to draw a state snapshot from the operator.
snapshotState(StateSnapshotContext) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
 
snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator, Optional<InternalTimeServiceManager<?>>, String, long, long, CheckpointOptions, CheckpointStreamFactory, boolean) - 类 中的方法org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - 类 中的方法org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
 
snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - 类 中的方法org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
 
snapshotTimersForKeyGroup(int) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx.
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
Snapshots the timers to raw keyed state.
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
 
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - 类 中的方法org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
 
SOCKET_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
SocketClientSink<IN> - org.apache.flink.streaming.api.functions.sink中的类
Socket client that acts as a streaming sink.
SocketClientSink(String, int, SerializationSchema<IN>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.SocketClientSink
Creates a new SocketClientSink.
SocketClientSink(String, int, SerializationSchema<IN>, int) - 类 的构造器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) - 类 的构造器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> - org.apache.flink.streaming.experimental中的类
An iterator that returns the data from a socket stream.
SocketStreamIterator(TypeSerializer<T>) - 类 的构造器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>) - 类 的构造器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) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
socketTextStream(String, int, String, long) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
socketTextStream(String, int, String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the strings received infinitely from a socket.
socketTextStream(String, int) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the strings received infinitely from a socket.
SocketTextStreamFunction - org.apache.flink.streaming.api.functions.source中的类
A source function that reads strings from a socket.
SocketTextStreamFunction(String, int, String, long) - 类 的构造器org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SocketTextStreamFunction(String, int, String, long, long) - 类 的构造器org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SortingDataInput<T,K> - 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) - 类 的构造器org.apache.flink.streaming.api.operators.sort.SortingDataInput
 
SourceFunction<T> - org.apache.flink.streaming.api.functions.source中的接口
Base interface for all stream data sources in Flink.
SourceFunction.SourceContext<T> - org.apache.flink.streaming.api.functions.source中的接口
Interface that source functions use to emit elements, and possibly watermarks.
SourceInputConfig(StreamEdge) - 类 的构造器org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
 
SourceOperator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit> - 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) - 类 的构造器org.apache.flink.streaming.api.operators.SourceOperator
 
SourceOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的类
The Factory class for SourceOperator.
SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean) - 类 的构造器org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean, int) - 类 的构造器org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
SourceOperatorStreamTask<T> - org.apache.flink.streaming.runtime.tasks中的类
A subclass of StreamTask for executing the SourceOperator.
SourceOperatorStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
SourceOperatorStreamTask.AsyncDataOutputToOutput<T> - org.apache.flink.streaming.runtime.tasks中的类
Implementation of PushingAsyncDataInput.DataOutput that wraps a specific Output.
SourceOutputWithWatermarks<T> - org.apache.flink.streaming.api.operators.source中的类
Implementation of the SourceOutput.
SourceOutputWithWatermarks(PushingAsyncDataInput.DataOutput<T>, WatermarkOutput, WatermarkOutput, TimestampAssigner<T>, WatermarkGenerator<T>) - 类 的构造器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>> - org.apache.flink.streaming.runtime.tasks中的类
StreamTask for executing a StreamSource.
SourceStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
SourceTransformation<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - org.apache.flink.streaming.api.transformations中的类
SourceTransformation(String, Source<OUT, SplitT, EnumChkT>, WatermarkStrategy<OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.SourceTransformation
Creates a new Transformation with the given name, output type and parallelism.
SourceTransformationTranslator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - org.apache.flink.streaming.runtime.translators中的类
SourceTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
 
StandardSinkTopologies - org.apache.flink.streaming.api.connector.sink2中的类
This utility class provides building blocks for custom topologies.
start() - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
startLatencyMeasurement() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
Starts mailbox latency measurement.
startNewChain() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Starts a new task chain beginning at this operator.
startNewKey(K) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called whenever the traversal starts with a new key.
startPeriodicWatermarkEmits() - 类 中的方法org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
 
startPeriodicWatermarkEmits() - 类 中的方法org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
 
startPeriodicWatermarkEmits() - 接口 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Starts the local InternalTimerServiceImpl by: Setting the keySerialized and namespaceSerializer for the timers it will contain.
state - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
State() - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
State(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>, List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>, Optional<CONTEXT>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
stateBackend - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
Our state backend.
StatefulSequenceSource - 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) - 类 的构造器org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
Creates a source that emits all numbers from the given interval exactly once.
stateKeySelector - 类 中的变量org.apache.flink.streaming.api.operators.AbstractInput
KeySelector for extracting a key from an element being processed.
stateKeyType - 类 中的变量org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>, boolean) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
StateSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
StateSerializerConfigSnapshot(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
已过时。
 
StateSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
status - 类 中的变量org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
statusWatermarkValve - 类 中的变量org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
Valve that controls how watermarks and watermark statuses are forwarded.
StatusWatermarkValve - 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) - 类 的构造器org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
Returns a new StatusWatermarkValve.
StatusWatermarkValve.InputChannelStatus - 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 - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
stop(StopMode) - 类 中的方法org.apache.flink.streaming.api.operators.SourceOperator
 
stop() - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
stopPeriodicWatermarkEmits() - 类 中的方法org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
 
stopPeriodicWatermarkEmits() - 类 中的方法org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
 
stopPeriodicWatermarkEmits() - 接口 中的方法org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
Stops emitting periodic watermarks.
Strategy(AssignerWithPeriodicWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
Strategy(AssignerWithPunctuatedWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
StreamConfig - org.apache.flink.streaming.api.graph中的类
Internal configuration for a StreamOperator.
StreamConfig(Configuration) - 类 的构造器org.apache.flink.streaming.api.graph.StreamConfig
 
StreamConfig.InputConfig - org.apache.flink.streaming.api.graph中的接口
Interface representing chained inputs.
StreamConfig.InputRequirement - org.apache.flink.streaming.api.graph中的枚举
Requirements of the different inputs of an operator.
StreamConfig.NetworkInputConfig - org.apache.flink.streaming.api.graph中的类
A representation of a Network StreamConfig.InputConfig.
StreamConfig.SourceInputConfig - org.apache.flink.streaming.api.graph中的类
A serialized representation of an input.
StreamEdge - org.apache.flink.streaming.api.graph中的类
An edge in the streaming topology.
StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag) - 类 的构造器org.apache.flink.streaming.api.graph.StreamEdge
 
StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - 类 的构造器org.apache.flink.streaming.api.graph.StreamEdge
 
StreamEdge(StreamNode, StreamNode, int, long, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - 类 的构造器org.apache.flink.streaming.api.graph.StreamEdge
 
StreamElement - org.apache.flink.streaming.runtime.streamrecord中的类
An element in a data stream.
StreamElement() - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamElement
 
StreamElementQueue<OUT> - org.apache.flink.streaming.api.operators.async.queue中的接口
Interface for stream element queues for the AsyncWaitOperator.
StreamElementSerializer<T> - org.apache.flink.streaming.runtime.streamrecord中的类
StreamElementSerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
StreamElementSerializer.StreamElementSerializerConfigSnapshot<T> - org.apache.flink.streaming.runtime.streamrecord中的类
StreamElementSerializer.StreamElementSerializerSnapshot<T> - org.apache.flink.streaming.runtime.streamrecord中的类
Configuration snapshot specific to the StreamElementSerializer.
StreamElementSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
StreamElementSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
StreamExchangeMode - org.apache.flink.streaming.api.transformations中的枚举
The data exchange mode between operators during StreamGraph generation.
StreamExecutionEnvironment - org.apache.flink.streaming.api.environment中的类
The StreamExecutionEnvironment is the context in which a streaming program is executed.
StreamExecutionEnvironment() - 类 的构造器org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
StreamExecutionEnvironment(Configuration) - 类 的构造器org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
StreamExecutionEnvironment(Configuration, ClassLoader) - 类 的构造器org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
StreamExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - 类 的构造器org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
StreamExecutionEnvironmentFactory - org.apache.flink.streaming.api.environment中的接口
Factory class for stream execution environments.
StreamFilter<IN> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing FilterFunctions.
StreamFilter(FilterFunction<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamFilter
 
StreamFlatMap<IN,OUT> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing FlatMapFunctions.
StreamFlatMap(FlatMapFunction<IN, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamFlatMap
 
StreamGraph - org.apache.flink.streaming.api.graph中的类
Class representing the streaming topology.
StreamGraph(ExecutionConfig, CheckpointConfig, SavepointRestoreSettings) - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraph
 
StreamGraphGenerator - org.apache.flink.streaming.api.graph中的类
A generator that generates a StreamGraph from a graph of Transformations.
StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig) - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig, ReadableConfig) - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
StreamGraphHasher - org.apache.flink.streaming.api.graph中的接口
Interface for different implementations of generating hashes over a stream graph.
StreamGraphHasherV2 - org.apache.flink.streaming.api.graph中的类
StreamGraphHasher from Flink 1.2.
StreamGraphHasherV2() - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraphHasherV2
 
StreamGraphUserHashHasher - org.apache.flink.streaming.api.graph中的类
StreamGraphHasher that works with user provided hashes.
StreamGraphUserHashHasher() - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
 
StreamGraphUtils - org.apache.flink.streaming.util.graph中的类
Utility class that contains helper methods to generating StreamGraph.
StreamGraphUtils() - 类 的构造器org.apache.flink.streaming.util.graph.StreamGraphUtils
 
StreamGroupedReduceOperator<IN> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing a ReduceFunction on a KeyedStream.
StreamGroupedReduceOperator(ReduceFunction<IN>, TypeSerializer<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
 
StreamingFileSink<IN> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
Use org.apache.flink.connector.file.sink.FileSink instead.
StreamingFileSink(StreamingFileSink.BucketsBuilder<IN, ?, ? extends StreamingFileSink.BucketsBuilder<IN, ?, ?>>, long) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
已过时。
Creates a new StreamingFileSink that writes files to the given base directory with the give buckets properties.
StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
A builder for configuring the sink for bulk-encoding formats, e.g.
StreamingFileSink.DefaultBulkFormatBuilder<IN> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
Builder for the vanilla StreamingFileSink using a bulk format.
StreamingFileSink.DefaultRowFormatBuilder<IN> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
Builder for the vanilla StreamingFileSink using a row format.
StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
已过时。
A builder for configuring the sink for row-wise encoding formats.
StreamingFileSinkHelper<IN> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
Helper for StreamingFileSink.
StreamingFileSinkHelper(Buckets<IN, ?>, boolean, OperatorStateStore, ProcessingTimeService, long) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
StreamingFunctionUtils - org.apache.flink.streaming.util.functions中的类
Utility class that contains helper methods to work with Flink Streaming Functions.
StreamingJobGraphGenerator - org.apache.flink.streaming.api.graph中的类
The StreamingJobGraphGenerator converts a StreamGraph into a JobGraph.
StreamingRuntimeContext - org.apache.flink.streaming.api.operators中的类
Implementation of the RuntimeContext, for streaming operators.
StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
StreamingRuntimeContext(Environment, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, OperatorID, ProcessingTimeService, KeyedStateStore, ExternalResourceInfoProvider) - 类 的构造器org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
StreamInputProcessor - org.apache.flink.streaming.runtime.io中的接口
Interface for processing records by StreamTask.
StreamIterationHead<OUT> - org.apache.flink.streaming.runtime.tasks中的类
A special StreamTask that is used for executing feedback edges.
StreamIterationHead(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
StreamIterationTail<IN> - org.apache.flink.streaming.runtime.tasks中的类
A special StreamTask that is used for executing feedback edges.
StreamIterationTail(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
StreamMap<IN,OUT> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing MapFunctions.
StreamMap(MapFunction<IN, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamMap
 
StreamMultipleInputProcessor - org.apache.flink.streaming.runtime.io中的类
Input processor for MultipleInputStreamOperator.
StreamMultipleInputProcessor(MultipleInputSelectionHandler, StreamOneInputProcessor<?>[]) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
StreamMultipleInputProcessorFactory - org.apache.flink.streaming.runtime.io中的类
StreamMultipleInputProcessorFactory() - 类 的构造器org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
 
StreamNode - 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>) - 类 的构造器org.apache.flink.streaming.api.graph.StreamNode
 
StreamNode(Integer, String, String, StreamOperatorFactory<?>, String, Class<? extends TaskInvokable>) - 类 的构造器org.apache.flink.streaming.api.graph.StreamNode
 
StreamOneInputProcessor<IN> - org.apache.flink.streaming.runtime.io中的类
Input reader for OneInputStreamTask.
StreamOneInputProcessor(StreamTaskInput<IN>, PushingAsyncDataInput.DataOutput<IN>, BoundedMultiInput) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
StreamOperator<OUT> - org.apache.flink.streaming.api.operators中的接口
Basic interface for stream operators.
StreamOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的接口
A factory to create StreamOperator.
StreamOperatorFactoryUtil - org.apache.flink.streaming.api.operators中的类
A utility to instantiate new operators with a given factory.
StreamOperatorFactoryUtil() - 类 的构造器org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
 
StreamOperatorParameters<OUT> - org.apache.flink.streaming.api.operators中的类
Helper class to construct AbstractStreamOperatorV2.
StreamOperatorParameters(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>, Supplier<ProcessingTimeService>, OperatorEventDispatcher) - 类 的构造器org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
StreamOperatorStateContext - 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. backends, raw state, and timer service manager.
streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializer
Returns the StreamOperatorStateContext for an AbstractStreamOperator that runs in the stream task that owns this manager.
streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamOperatorStateHandler - org.apache.flink.streaming.api.operators中的类
Class encapsulating various state backend handling logic for StreamOperator implementations.
StreamOperatorStateHandler(StreamOperatorStateContext, ExecutionConfig, CloseableRegistry) - 类 的构造器org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
StreamOperatorStateHandler.CheckpointedStreamOperator - org.apache.flink.streaming.api.operators中的接口
Custom state handling hooks to be invoked by StreamOperatorStateHandler.
StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> - org.apache.flink.streaming.runtime.tasks中的类
This class handles the finish, endInput and other related logic of a StreamOperator.
streamOutputs - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
StreamPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
A special ChannelSelector for use in streaming programs.
StreamPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
StreamPipelineOptions - org.apache.flink.streaming.api.environment中的类
The configuration options for job execution.
StreamPipelineOptions() - 类 的构造器org.apache.flink.streaming.api.environment.StreamPipelineOptions
 
StreamProject<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing projections on streams.
StreamProject(int[], TypeSerializer<OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamProject
 
StreamProjection<IN> - org.apache.flink.streaming.api.datastream中的类
StreamProjection(DataStream<IN>, int[]) - 类 的构造器org.apache.flink.streaming.api.datastream.StreamProjection
 
StreamRecord<T> - org.apache.flink.streaming.runtime.streamrecord中的类
One value in a data stream.
StreamRecord(T) - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a new StreamRecord.
StreamRecord(T, long) - 类 的构造器org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a new StreamRecord wrapping the given value.
StreamSink<IN> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing SinkFunctions.
StreamSink(SinkFunction<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamSink
 
StreamSource<OUT,SRC extends SourceFunction<OUT>> - org.apache.flink.streaming.api.operators中的类
StreamOperator for streaming sources.
StreamSource(SRC, boolean) - 类 的构造器org.apache.flink.streaming.api.operators.StreamSource
 
StreamSource(SRC) - 类 的构造器org.apache.flink.streaming.api.operators.StreamSource
 
StreamSourceContexts - org.apache.flink.streaming.api.operators中的类
Source contexts for various stream time characteristics.
StreamSourceContexts() - 类 的构造器org.apache.flink.streaming.api.operators.StreamSourceContexts
 
StreamTask<OUT,OP extends StreamOperator<OUT>> - org.apache.flink.streaming.runtime.tasks中的类
Base class for all streaming tasks.
StreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
 
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor, TaskMailbox) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
 
StreamTaskActionExecutor - org.apache.flink.streaming.runtime.tasks中的接口
Executes Runnable, ThrowingRunnable, or Callable.
StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor - org.apache.flink.streaming.runtime.tasks中的类
已过时。
this class should only be used in SourceStreamTask which exposes the checkpoint lock as part of Public API.
StreamTaskException - org.apache.flink.streaming.runtime.tasks中的异常错误
An exception that is thrown by the stream vertices when encountering an illegal condition.
StreamTaskException() - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with no message and no cause.
StreamTaskException(String) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given message and no cause.
StreamTaskException(Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given cause and no message.
StreamTaskException(String, Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given message and cause.
StreamTaskExternallyInducedSourceInput<T> - org.apache.flink.streaming.runtime.io中的类
A subclass of StreamTaskSourceInput for ExternallyInducedSourceReader.
StreamTaskExternallyInducedSourceInput(SourceOperator<T, ?>, Consumer<Long>, int, int) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
 
StreamTaskFinishedOnRestoreSourceInput<T> - org.apache.flink.streaming.runtime.tasks中的类
A special source input implementation that immediately emit END_OF_INPUT.
StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T, ?>, int, int) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
 
StreamTaskInput<T> - org.apache.flink.streaming.runtime.io中的接口
Basic interface for inputs of stream operators.
StreamTaskNetworkInput<T> - org.apache.flink.streaming.runtime.io中的类
Implementation of StreamTaskInput that wraps an input from network taken from CheckpointedInputGate.
StreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
StreamTaskNetworkInputFactory - org.apache.flink.streaming.runtime.io中的类
StreamTaskNetworkInputFactory() - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
 
StreamTaskSourceInput<T> - org.apache.flink.streaming.runtime.io中的类
Implementation of StreamTaskInput that reads data from the SourceOperator and returns the DataInputStatus to indicate whether the source state is available, unavailable or finished.
StreamTaskSourceInput(SourceOperator<T, ?>, int, int) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
StreamTaskStateInitializer - org.apache.flink.streaming.api.operators中的接口
This is the interface through which stream task expose a StreamOperatorStateContext to their operators.
StreamTaskStateInitializerImpl - org.apache.flink.streaming.api.operators中的类
This class is the main implementation of a StreamTaskStateInitializer.
StreamTaskStateInitializerImpl(Environment, StateBackend) - 类 的构造器org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamTaskStateInitializerImpl(Environment, StateBackend, TtlTimeProvider, InternalTimeServiceManager.Provider) - 类 的构造器org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamTwoInputProcessorFactory - org.apache.flink.streaming.runtime.io中的类
A factory to create StreamMultipleInputProcessor for two input case.
StreamTwoInputProcessorFactory() - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
 
stringGenerator(int) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
stringGenerator(long, long) - 类 中的静态方法org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
SubtaskCheckpointCoordinator - org.apache.flink.streaming.runtime.tasks中的接口
Coordinates checkpointing-related work for a subtask (i.e.
subtaskReset(int, long) - 类 中的方法org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
sum(int) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that sums every window of the data stream at the given position.
sum(String) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that sums every window of the data stream at the given position.
sum(String) - 类 中的方法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> - org.apache.flink.streaming.api.functions.aggregation中的类
An AggregationFunction that sums up fields.
SumAggregator(int, TypeInformation<T>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
SumAggregator(String, TypeInformation<T>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
SumFunction - org.apache.flink.streaming.api.functions.aggregation中的类
Internal function for summing up contents of fields.
SumFunction() - 类 的构造器org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
supportsUnalignedCheckpoints() - 类 中的方法org.apache.flink.streaming.api.graph.NonChainedOutput
 
supportsUnalignedCheckpoints() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
suspend() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Suspend the running of the loop which was started by MailboxProcessor.runMailboxLoop()}.
suspendDefaultAction(PeriodTimer) - 接口 中的方法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. because there is currently no input available.
suspendDefaultAction() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
Same as MailboxDefaultAction.Controller.suspendDefaultAction(PeriodTimer) but without any associated timer measuring the idle time.
suspendDefaultAction(PeriodTimer) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
suspendDefaultAction() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
synchronizedExecutor() - 接口 中的静态方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
Returns an ExecutionDecorator that synchronizes each invocation.
synchronizedExecutor(Object) - 接口 中的静态方法org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
Returns an ExecutionDecorator that synchronizes each invocation on a given object.
SynchronizedStreamTaskActionExecutor(Object) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
已过时。
 
SystemProcessingTimeService - org.apache.flink.streaming.runtime.tasks中的类
A TimerService which assigns as current processing time the result of calling System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor.
systemTimerService - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
In contrast to StreamTask.timerService we should not register any user timers here.

T

tailOperatorWrapper - 类 中的变量org.apache.flink.streaming.runtime.tasks.OperatorChain
 
take(int) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TaskMailbox - 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 - org.apache.flink.streaming.runtime.tasks.mailbox中的异常错误
Exception thrown when TaskMailbox is closed.
TaskMailbox.State - org.apache.flink.streaming.runtime.tasks.mailbox中的枚举
This enum represents the states of the mailbox lifecycle.
TaskMailboxImpl - 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) - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TaskMailboxImpl() - 类 的构造器org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TestProcessingTimeService - org.apache.flink.streaming.runtime.tasks中的类
This is a TimerService and ProcessingTimeService used strictly for testing the processing time functionality.
TestProcessingTimeService() - 类 的构造器org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
Time - org.apache.flink.streaming.api.windowing.time中的类
The definition of a time interval for windowing.
TIME_CHARACTERISTIC - 类 中的静态变量org.apache.flink.streaming.api.environment.StreamPipelineOptions
 
TimeCharacteristic - org.apache.flink.streaming.api中的枚举
已过时。
In Flink 1.12 the default stream time characteristic has been changed to TimeCharacteristic.EventTime, thus you don't need to call this method for enabling event-time support anymore. Explicitly using processing-time windows and timers works in event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long). If you are using TimeCharacteristic.IngestionTime, please manually set an appropriate WatermarkStrategy. If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time) that change behaviour based on the time characteristic, please use equivalent operations that explicitly specify processing time or event time.
timeDomain() - 类 中的方法org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
The TimeDomain of the firing timer, i.e. if it is event or processing time timer.
timeDomain() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
TimeDomain - org.apache.flink.streaming.api中的枚举
TimeDomain specifies whether a firing timer is based on event time or processing time.
TimeEvictor<W extends Window> - org.apache.flink.streaming.api.windowing.evictors中的类
An Evictor that keeps elements for a certain amount of time.
TimeEvictor(long) - 类 的构造器org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
TimeEvictor(long, boolean) - 类 的构造器org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
timeout(IN, ResultFuture<OUT>) - 接口 中的方法org.apache.flink.streaming.api.functions.async.AsyncFunction
Timer(long, K, W) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
TIMER_COMPARATOR - 接口 中的静态变量org.apache.flink.streaming.api.operators.InternalTimer
Function to compare instances of InternalTimer.
TimerException - 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) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.TimerException
 
TimerHeapInternalTimer<K,N> - org.apache.flink.streaming.api.operators中的类
Implementation of InternalTimer to use with a HeapPriorityQueueSet.
TimerHeapInternalTimer(long, K, N) - 类 的构造器org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
TimerSerializer<K,N> - 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>) - 类 的构造器org.apache.flink.streaming.api.operators.TimerSerializer
 
TimerSerializer.TimerSerializerConfigSnapshot<K,N> - org.apache.flink.streaming.api.operators中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by TimerSerializerSnapshot.
TimerSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
已过时。
 
TimerSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<N>) - 类 的构造器org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
已过时。
 
TimerSerializerSnapshot<K,N> - org.apache.flink.streaming.api.operators中的类
Snapshot class for the TimerSerializer.
TimerSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
TimerSerializerSnapshot(TimerSerializer<K, N>) - 类 的构造器org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
timerService() - 类 中的方法org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
A TimerService for querying time and registering timers.
timerService() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction.Context
A TimerService for querying time and registering timers.
TimerService - org.apache.flink.streaming.api中的接口
Interface for working with time and timers.
timerService - 类 中的变量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 - org.apache.flink.streaming.runtime.tasks中的接口
A common timer service interface with life cycle methods.
timestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - 类 中的方法org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - 类 中的方法org.apache.flink.streaming.api.functions.ProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - 接口 中的方法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 - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
TimestampAssigner<T> - org.apache.flink.streaming.api.functions中的接口
已过时。
use TimestampAssigner
TimestampedCollector<T> - org.apache.flink.streaming.api.operators中的类
Wrapper around an Output for user functions that expect a Output.
TimestampedCollector(Output<StreamRecord<T>>) - 类 的构造器org.apache.flink.streaming.api.operators.TimestampedCollector
Creates a new TimestampedCollector that wraps the given Output.
timestampedCollector - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
This is given to the InternalWindowFunction for emitting elements with a given timestamp.
TimestampedFileInputSplit - org.apache.flink.streaming.api.functions.source中的类
A FileInputSplit with TimestampedInputSplit.
TimestampedFileInputSplit(long, int, Path, long, long, String[]) - 类 的构造器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 - 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> - org.apache.flink.streaming.runtime.operators.windowing中的类
Stores the value and the timestamp of the record.
TimestampedValue(T) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a new TimestampedValue.
TimestampedValue(T, long) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a new TimestampedValue wrapping the given value.
TimestampsAndWatermarks<T> - org.apache.flink.streaming.api.operators.source中的接口
Basic interface for the timestamp extraction and watermark generation logic for the SourceReader.
TimestampsAndWatermarks.WatermarkUpdateListener - org.apache.flink.streaming.api.operators.source中的接口
Lets the owner/creator of the output know about latest emitted watermark.
TimestampsAndWatermarksContext - org.apache.flink.streaming.api.operators.source中的类
A simple implementation of a context that is both TimestampAssignerSupplier.Context and WatermarkGeneratorSupplier.Context.
TimestampsAndWatermarksContext(MetricGroup) - 类 的构造器org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
 
TimestampsAndWatermarksOperator<T> - 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) - 类 的构造器org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
TimestampsAndWatermarksOperator.WatermarkEmitter - org.apache.flink.streaming.runtime.operators中的类
Implementation of the WatermarkEmitter, based on the components that are available inside a stream operator.
TimestampsAndWatermarksTransformation<IN> - org.apache.flink.streaming.api.transformations中的类
TimestampsAndWatermarksTransformation(String, int, Transformation<IN>, WatermarkStrategy<IN>) - 类 的构造器org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
Creates a new Transformation with the given name, output type and parallelism.
TimestampsAndWatermarksTransformationTranslator<IN> - org.apache.flink.streaming.runtime.translators中的类
TimestampsAndWatermarksTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
 
timeWindow(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
已过时。
Please use KeyedStream.window(WindowAssigner) with either TumblingEventTimeWindows or TumblingProcessingTimeWindows. For more information, see the deprecation notice on TimeCharacteristic
timeWindow(Time, Time) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
已过时。
Please use KeyedStream.window(WindowAssigner) with either SlidingEventTimeWindows or SlidingProcessingTimeWindows. For more information, see the deprecation notice on TimeCharacteristic
TimeWindow - org.apache.flink.streaming.api.windowing.windows中的类
A Window that represents a time interval from start (inclusive) to end (exclusive).
TimeWindow(long, long) - 类 的构造器org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
TimeWindow.Serializer - org.apache.flink.streaming.api.windowing.windows中的类
The serializer used to write the TimeWindow type.
TimeWindow.Serializer.TimeWindowSerializerSnapshot - org.apache.flink.streaming.api.windowing.windows中的类
Serializer configuration snapshot for compatibility and format evolution.
timeWindowAll(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use DataStream.windowAll(WindowAssigner) with either TumblingEventTimeWindows or TumblingProcessingTimeWindows. For more information, see the deprecation notice on TimeCharacteristic
timeWindowAll(Time, Time) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use DataStream.windowAll(WindowAssigner) with either SlidingEventTimeWindows or SlidingProcessingTimeWindows. For more information, see the deprecation notice on TimeCharacteristic
TimeWindowSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer.TimeWindowSerializerSnapshot
 
TOLERABLE_FAILURE_NUMBER - 类 中的静态变量org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
toMilliseconds() - 类 中的方法org.apache.flink.streaming.api.windowing.time.Time
Converts the time interval to milliseconds.
toString() - 类 中的方法org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
 
toString() - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.sink.PrintSink
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
toString() - 类 中的方法org.apache.flink.streaming.api.operators.InputSelection
 
toString() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
toString() - 类 中的方法org.apache.flink.streaming.api.watermark.Watermark
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
toString() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
toString() - 异常错误 中的方法org.apache.flink.streaming.runtime.tasks.TimerException
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
TransactionHolder(TXN, long) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
 
transform(String, TypeInformation<R>, TwoInputStreamOperatorFactory<IN1, IN2, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
 
transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
transform(Transformation<?>) - 接口 中的方法org.apache.flink.streaming.api.graph.TransformationTranslator.Context
Transforms the transformation and updates the current stream graph.
transformation - 类 中的变量org.apache.flink.streaming.api.datastream.DataStream
 
transformations - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
TransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - 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 - org.apache.flink.streaming.api.graph中的接口
A context giving the necessary information for the translation of a given transformation.
translateForBatch(T, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
 
translateForBatch(T, TransformationTranslator.Context) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
 
translateForBatchInternal(T, TransformationTranslator.Context) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
 
translateForBatchInternal(T, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
 
translateForBatchInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
 
translateForBatchInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
 
translateForBatchInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
 
translateForBatchInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
 
translateForBatchInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
 
translateForBatchInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
 
translateForBatchInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
 
translateForBatchInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
 
translateForBatchInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
 
translateForBatchInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
 
translateForBatchInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
 
translateForBatchInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
 
translateForStreaming(T, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
 
translateForStreaming(T, TransformationTranslator.Context) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
 
translateForStreamingInternal(T, TransformationTranslator.Context) - 类 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
 
translateForStreamingInternal(T, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
 
translateForStreamingInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
 
translateForStreamingInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
 
translateForStreamingInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
 
translateForStreamingInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
 
translateForStreamingInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
 
translateForStreamingInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
 
translateForStreamingInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
 
translateForStreamingInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
 
translateForStreamingInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
 
translateForStreamingInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
 
translateForStreamingInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
 
translateForStreamingInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
 
translateInternal(Transformation<OUT>, Transformation<IN1>, Transformation<IN2>, StreamOperatorFactory<OUT>, TypeInformation<?>, KeySelector<IN1, ?>, KeySelector<IN2, ?>, TransformationTranslator.Context) - 类 中的方法org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
 
traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - 类 中的静态方法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) - 接口 中的方法org.apache.flink.streaming.api.graph.StreamGraphHasher
Returns a map with a hash for each StreamNode of the StreamGraph.
traverseStreamGraphAndGenerateHashes(StreamGraph) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphHasherV2
Returns a map with a hash for each StreamNode of the StreamGraph.
traverseStreamGraphAndGenerateHashes(StreamGraph) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
 
trigger(Trigger<? super T, ? super W>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
Sets the Trigger that should be used to trigger window emission.
Trigger<T,W extends Window> - 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() - 类 的构造器org.apache.flink.streaming.api.windowing.triggers.Trigger
 
trigger(Trigger<? super T, ? super W>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
Trigger.OnMergeContext - org.apache.flink.streaming.api.windowing.triggers中的接口
Trigger.TriggerContext - 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 - 类 中的静态变量org.apache.flink.streaming.runtime.tasks.StreamTask
The thread group that holds all trigger timer threads.
Triggerable<K,N> - org.apache.flink.streaming.api.operators中的接口
Interface for things that can be called by InternalTimerService.
triggerCheckpoint(long) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
Triggers a checkpoint.
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - 类 中的方法org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerContext - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
TriggerResult - org.apache.flink.streaming.api.windowing.triggers中的枚举
Result type for trigger methods.
triggerSerializationAndReturnFuture(Executor) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
Trigger the object config serialization and return the completable future.
tryCancel(boolean) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
tryPut(StreamElement) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
tryPut(StreamElement) - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Tries to put the given element in the queue.
tryPut(StreamElement) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
tryTake(int) - 接口 中的方法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) - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
tryTakeFromBatch() - 接口 中的方法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() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
tryYield() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
TumblingEventTimeWindows - 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) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
TumblingProcessingTimeWindows - 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 - 类 中的变量org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
 
two(T2) - 类 中的静态方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
TwoInputStreamOperator<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators中的接口
Interface for stream operators with two inputs.
TwoInputStreamOperatorFactory<IN1,IN2,OUT> - org.apache.flink.streaming.api.operators中的接口
A factory to create TwoInputStreamOperator.
TwoInputStreamTask<IN1,IN2,OUT> - org.apache.flink.streaming.runtime.tasks中的类
A StreamTask for executing a TwoInputStreamOperator and supporting the TwoInputStreamOperator to select input for reading.
TwoInputStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
TwoInputTransformation<IN1,IN2,OUT> - org.apache.flink.streaming.api.transformations中的类
This Transformation represents the application of a TwoInputStreamOperator to two input Transformations.
TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.TwoInputTransformation
Creates a new TwoInputTransformation from the given inputs and operator.
TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
TwoInputTransformationTranslator<IN1,IN2,OUT> - org.apache.flink.streaming.runtime.translators中的类
TwoInputTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
 
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> - 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>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Use default ListStateDescriptor for internal state serialization.
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> - org.apache.flink.streaming.api.functions.sink中的类
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> - org.apache.flink.streaming.api.functions.sink中的类
Custom TypeSerializer for the sink state.
TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot<TXN,CONTEXT> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by TwoPhaseCommitSinkFunction.StateSerializerSnapshot.
TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> - org.apache.flink.streaming.api.functions.sink中的类
TwoPhaseCommitSinkFunction.TransactionHolder<TXN> - org.apache.flink.streaming.api.functions.sink中的类
Adds metadata (currently only the start time of the transaction) to the transaction object.
TYPE - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
TypeInformationSerializationSchema<T> - org.apache.flink.streaming.util.serialization中的类
已过时。
Use TypeInformationSerializationSchema instead.
TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - 类 的构造器org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
已过时。
Creates a new de-/serialization schema for the given type.

U

UdfStreamOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的接口
Udf stream operator factory.
uid(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStreamSink
Sets an ID for this operator.
uid(String) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets an ID for this operator.
unaligned(String, CheckpointableTask, SubtaskCheckpointCoordinator, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - 类 中的静态方法org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
 
UncheckpointedCollectResultBuffer<T> - org.apache.flink.streaming.api.operators.collect中的类
A buffer which encapsulates the logic of dealing with the response from the CollectSinkFunction.
UncheckpointedCollectResultBuffer(TypeSerializer<T>, boolean) - 类 的构造器org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
 
UNDEFINED_TOLERABLE_CHECKPOINT_NUMBER - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
 
UNINITIALIZED - 类 中的静态变量org.apache.flink.streaming.api.watermark.Watermark
The watermark that signifies is used before any actual watermark has been generated.
union(DataStream<T>...) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Creates a new DataStream by merging DataStream outputs of the same type with each other.
UnionSerializer(TypeSerializer<T1>, TypeSerializer<T2>) - 类 的构造器org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
UnionSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
UnionSerializerConfigSnapshot(TypeSerializer<T1>, TypeSerializer<T2>) - 类 的构造器org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
已过时。
 
UnionSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
UnionTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This transformation represents a union of several input Transformations.
UnionTransformation(List<Transformation<T>>) - 类 的构造器org.apache.flink.streaming.api.transformations.UnionTransformation
Creates a new UnionTransformation from the given input Transformations.
UnionTransformationTranslator<OUT> - org.apache.flink.streaming.runtime.translators中的类
UnionTransformationTranslator() - 类 的构造器org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
 
UnorderedStreamElementQueue<OUT> - org.apache.flink.streaming.api.operators.async.queue中的类
Unordered implementation of the StreamElementQueue.
UnorderedStreamElementQueue(int) - 类 的构造器org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator.
unorderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, AsyncRetryStrategy<OUT>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
unorderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, AsyncRetryStrategy<OUT>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
UNSPECIFIED - 接口 中的静态变量org.apache.flink.streaming.runtime.io.StreamTaskInput
 
UNSUPPORTED_DELETE_TIMER_MSG - 接口 中的静态变量org.apache.flink.streaming.api.TimerService
Error string for UnsupportedOperationException on deleting timers.
UNSUPPORTED_REGISTER_TIMER_MSG - 接口 中的静态变量org.apache.flink.streaming.api.TimerService
Error string for UnsupportedOperationException on registering timers.
UnsupportedTimeCharacteristicException - org.apache.flink.streaming.api.datastream中的异常错误
An exception that indicates that a time characteristic was used that is not supported in the current operation.
UnsupportedTimeCharacteristicException(String) - 异常错误 的构造器org.apache.flink.streaming.api.datastream.UnsupportedTimeCharacteristicException
 
update(List<T>) - 类 中的方法org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
updateAndRetryLater(CommT) - 类 中的方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
 
updateCondition() - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
Condition for writing the contents of tupleList and clearing it.
updateCondition() - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
已过时。
 
updateCurrentEffectiveWatermark(long) - 接口 中的方法org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.WatermarkUpdateListener
Effective watermark covers the WatermarkStatus.
updateStatusAndSelection(DataInputStatus, int) - 类 中的方法org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
upperBoundExclusive() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the upper bound to be exclusive.
UpstreamRecoveryTracker - org.apache.flink.streaming.runtime.io.checkpointing中的接口
Tracks status of upstream channels while they recover.
userContext - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
userFunction - 类 中的变量org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
The user function.

V

validateTransformationUid(StreamGraph, Transformation<?>) - 类 中的静态方法org.apache.flink.streaming.util.graph.StreamGraphUtils
Throw IllegalStateException if the PhysicalTransformation's uid or hash is not set when auto generate uid is disabled.
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.CheckpointingMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.functions.source.FileProcessingMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.operators.ChainingStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.TimeCharacteristic
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.TimeDomain
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.transformations.StreamExchangeMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.windowing.assigners.WindowStagger
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.api.windowing.triggers.TriggerResult
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.runtime.io.DataInputStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.streaming.util.LatencyStats.Granularity
返回带有指定名称的该类型的枚举常量。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.CheckpointingMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.functions.source.FileProcessingMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
values() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Returns the collection of StreamElement currently contained in this queue for checkpointing.
values() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
values() - 枚举 中的静态方法org.apache.flink.streaming.api.operators.ChainingStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.TimeCharacteristic
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.TimeDomain
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.transformations.StreamExchangeMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.windowing.assigners.WindowStagger
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.api.windowing.triggers.TriggerResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.runtime.io.DataInputStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.util.LatencyStats.Granularity
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
valuesToEmit - 类 中的变量org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
VERSION - 类 中的静态变量org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
vertexIDtoBrokerID - 类 中的变量org.apache.flink.streaming.api.graph.StreamGraph
 
vertexIDtoLoopTimeout - 类 中的变量org.apache.flink.streaming.api.graph.StreamGraph
 

W

waitForPendingCheckpoints() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Waits for all the pending checkpoints to finish their asynchronous step.
Watermark - 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) - 类 的构造器org.apache.flink.streaming.api.watermark.Watermark
Creates a new watermark with the given timestamp in milliseconds.
watermark - 类 中的变量org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
 
WatermarkEmitter(Output<?>) - 类 的构造器org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
 
WatermarkGauge - org.apache.flink.streaming.runtime.metrics中的类
A Gauge for exposing the current input/output watermark.
WatermarkGauge() - 类 的构造器org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
WatermarkGaugeExposingOutput<T> - org.apache.flink.streaming.runtime.tasks中的接口
An Output that measures the last emitted watermark with a WatermarkGauge.
watermarkStatus - 类 中的变量org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.InputChannelStatus
 
WatermarkStatus - 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) - 类 的构造器org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
 
WatermarkToDataOutput - org.apache.flink.streaming.api.operators.source中的类
An adapter that exposes a WatermarkOutput based on a PushingAsyncDataInput.DataOutput.
WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>) - 类 的构造器org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>, TimestampsAndWatermarks.WatermarkUpdateListener) - 类 的构造器org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
Creates a new WatermarkOutput against the given DataOutput.
where(KeySelector<T1, KEY>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams
Specifies a KeySelector for elements from the first input.
where(KeySelector<T1, KEY>, TypeInformation<KEY>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams
Specifies a KeySelector for elements from the first input with explicit type information.
where(KeySelector<T1, KEY>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams
Specifies a KeySelector for elements from the first input.
where(KeySelector<T1, KEY>, TypeInformation<KEY>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
Specifies the window on which the join operation works.
window(WindowAssigner<? super T, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Windows this data stream to a WindowedStream, which evaluates windows over a key grouped stream.
window() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
window() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
window() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
window() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the window that is being evaluated.
Window - org.apache.flink.streaming.api.windowing.windows中的类
A Window is a grouping of elements into finite buckets.
Window() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.Window
 
window() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
window() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
window - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
window - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
window - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
window - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
windowAll(WindowAssigner<? super T, W>) - 类 中的方法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> - org.apache.flink.streaming.api.windowing.assigners中的类
A WindowAssigner assigns zero or more Windows to an element.
WindowAssigner() - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
 
windowAssigner - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
WindowAssigner.WindowAssignerContext - org.apache.flink.streaming.api.windowing.assigners中的类
A context provided to the WindowAssigner that allows it to query the current processing time.
WindowAssignerContext() - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
 
windowAssignerContext - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
WindowContext(W) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
WindowedStream<T,K,W extends Window> - 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>) - 类 的构造器org.apache.flink.streaming.api.datastream.WindowedStream
 
WindowFunction<IN,OUT,KEY,W extends Window> - 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> - org.apache.flink.streaming.runtime.operators.windowing中的类
An operator that implements the logic for windowing based on a WindowAssigner and Trigger.
WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Creates a new WindowOperator based on the given policies and user functions.
WindowOperator.AbstractPerWindowStateStore - org.apache.flink.streaming.runtime.operators.windowing中的类
Base class for per-window KeyedStateStores.
WindowOperator.Context - org.apache.flink.streaming.runtime.operators.windowing中的类
Context is a utility for handling Trigger invocations.
WindowOperator.MergingWindowStateStore - org.apache.flink.streaming.runtime.operators.windowing中的类
Special WindowOperator.AbstractPerWindowStateStore that doesn't allow access to per-window state.
WindowOperator.PerWindowStateStore - org.apache.flink.streaming.runtime.operators.windowing中的类
Regular per-window state store for use with ProcessWindowFunction.
WindowOperator.Timer<K,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing中的类
Internal class for keeping track of in-flight timers.
WindowOperator.WindowContext - org.apache.flink.streaming.runtime.operators.windowing中的类
A utility class for handling ProcessWindowFunction invocations.
WindowOperatorBuilder<T,K,W extends Window> - org.apache.flink.streaming.runtime.operators.windowing中的类
A builder for creating WindowOperators.
WindowOperatorBuilder(WindowAssigner<? super T, W>, Trigger<? super T, ? super W>, ExecutionConfig, TypeInformation<T>, KeySelector<T, K>, TypeInformation<K>) - 类 的构造器org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
 
windowSerializer - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the window in checkpoints.
WindowStagger - org.apache.flink.streaming.api.windowing.assigners中的枚举
A WindowStagger staggers offset in runtime for each window assignment.
windowState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
windowState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
windowState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
windowState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
windowState() - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
windowState - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
windowState() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
with(CoGroupFunction<T1, T2, T>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
已过时。
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction) method is fixed in the next major version of Flink (2.0).
with(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
已过时。
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
已过时。
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction) method is fixed in the next major version of Flink (2.0).
with(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
已过时。
with(FlatJoinFunction<T1, T2, T>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
已过时。
This method will be removed once the JoinedStreams.WithWindow.apply(FlatJoinFunction) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>, TypeInformation<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
已过时。
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
WithBoundedness - org.apache.flink.streaming.api.transformations中的接口
An interface to be implemented by transformations that have explicitly set Boundedness.
withBucketAssigner(BucketAssigner<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
withBucketAssigner(BucketAssigner<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
withBucketCheckInterval(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
withBucketCheckInterval(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
withDynamicGap(SessionWindowTimeGapExtractor<T>) - 类 中的静态方法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>) - 类 中的静态方法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>) - 类 中的静态方法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>) - 类 中的静态方法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>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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) - 类 中的静态方法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) - 类 中的静态方法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> - 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>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
withNewBucketAssignerAndPolicy(BucketAssigner<IN, ID>, RollingPolicy<IN, ID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
withOutputFileConfig(OutputFileConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
withOutputFileConfig(OutputFileConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
WithPostCommitTopology<InputT,CommT> - org.apache.flink.streaming.api.connector.sink2中的接口
Allows expert users to implement a custom topology after Committer.
WithPreCommitTopology<InputT,CommT> - org.apache.flink.streaming.api.connector.sink2中的接口
Allows expert users to implement a custom topology after SinkWriter and before Committer.
WithPreWriteTopology<InputT> - org.apache.flink.streaming.api.connector.sink2中的接口
Allows expert users to implement a custom topology before SinkWriter.
withRollingPolicy(CheckpointRollingPolicy<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
已过时。
 
withRollingPolicy(RollingPolicy<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
已过时。
 
withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - 类 中的方法org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
已过时。
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) - 类 的构造器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) - 类 的构造器org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
 
wrap(Sink<InputT, ?, ?, ?>) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
 
write(String, ArrayList<IN>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteFormat
已过时。
Writes the contents of tupleList to the file specified by path.
write(String, ArrayList<IN>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
已过时。
 
write(String, ArrayList<IN>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
已过时。
 
write(DataOutputView) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
writeAsCsv(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsCsv(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsCsv(String, FileSystem.WriteMode, String, String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsText(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsText(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
WriteFormat<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormat() - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteFormat
已过时。
 
WriteFormatAsCsv<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormatAsCsv() - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
已过时。
 
WriteFormatAsText<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormatAsText() - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
已过时。
 
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
WriteSinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
WriteSinkFunction(String, WriteFormat<IN>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
已过时。
 
WriteSinkFunctionByMillis<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the StreamingFileSink for writing to files from a streaming program.
WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
已过时。
 
writeTimersSnapshot(DataOutputView) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter
Writes the timers snapshot to the output view.
writeToSocket(String, int, SerializationSchema<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes the DataStream to a socket as a byte array.
writeUsingOutputFormat(OutputFormat<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.SinkFunction
Writes the given watermark to the sink.

Y

yield() - 类 中的方法org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
YieldingOperatorFactory<OUT> - org.apache.flink.streaming.api.operators中的接口
An operator that needs access to the MailboxExecutor to yield to downstream operators needs to be created through a factory implementing this interface.
A B C D E F G H I J K L M N O P Q R S T U V W Y 
跳过导航链接

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