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

A

abort(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction.
abortCheckpointOnBarrier(long, Throwable) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
AbstractDeserializationSchema<T> - org.apache.flink.streaming.util.serialization中的类
已过时。
Use AbstractDeserializationSchema instead.
AbstractDeserializationSchema() - 类 的构造器org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
已过时。
 
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
 
AbstractStreamOperator.CountingOutput<OUT> - org.apache.flink.streaming.api.operators中的类
Wrapping Output that updates metrics on the number of emitted elements.
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
 
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.streamstatus.StreamStatus
 
ACTIVE_STATUS - 类 中的静态变量org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
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(BufferOrEvent) - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferBlocker
Adds a buffer or event to the blocker.
add(BufferOrEvent) - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
Adds a buffer or event to the sequence of spilled buffers and events.
add(BufferOrEvent) - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker
 
addCoOperator(Integer, String, String, TwoInputStreamOperator<IN1, IN2, 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
 
addFeedbackEdge(StreamTransformation<F>) - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Adds a feedback edge.
addFeedbackEdge(StreamTransformation<T>) - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Adds a feedback edge.
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
 
addNode(Integer, String, String, Class<? extends AbstractInvokable>, StreamOperator<?>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addOperator(StreamTransformation<?>) - 类 中的方法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, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addOutEdge(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
addOutputSelector(Integer, OutputSelector<T>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addOutputSelector(OutputSelector<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
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, StreamOperator<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
Ads 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, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain partitioning.
addVirtualSelectNode(Integer, Integer, List<String>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected names.
addVirtualSideOutputNode(Integer, Integer, OutputTag) - 类 中的方法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.
advanceWatermark(long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
advanceWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
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.
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.
allOutputs - 类 中的变量org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
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.
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.
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(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(R, FoldFunction<T, R>, AllWindowFunction<R, 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(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
apply(R, FoldFunction<T, R>, WindowFunction<R, 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<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
已过时。
 
apply(K, W, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
已过时。
 
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.
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.
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.
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中的类
A timestamp assigner and watermark generator for streams where timestamps are monotonously ascending.
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, FoldingStateDescriptor<T, ACC>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
已过时。
will be removed in a future version
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.
asResultCollection() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async result collection.
asResultCollection() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
AssignerWithPeriodicWatermarks<T> - org.apache.flink.streaming.api.functions中的接口
The AssignerWithPeriodicWatermarks assigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream.
AssignerWithPunctuatedWatermarks<T> - org.apache.flink.streaming.api.functions中的接口
The AssignerWithPunctuatedWatermarks assigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream.
assignTimestamps(TimestampExtractor<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and creates watermarks to signal event time progress based on the elements themselves.
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
已过时。
 
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.
asStreamStatus() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamStatus.
asWatermark() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async watermark result.
asWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
asWatermark() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
AsyncCollectionResult<T> - org.apache.flink.streaming.api.operators.async.queue中的接口
AsyncResult sub class for asynchronous result collections.
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.
AsyncExceptionHandler - org.apache.flink.streaming.runtime.tasks中的接口
An interface marking a task as capable of handling exceptions thrown by different threads, other than the one executing the task itself.
AsyncFunction<IN,OUT> - org.apache.flink.streaming.api.functions.async中的接口
A function to trigger Async I/O operation.
AsynchronousException - org.apache.flink.streaming.runtime.tasks中的异常错误
An exception for wrapping exceptions that are thrown by an operator in threads other than the main compute thread of that operator.
AsynchronousException(Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
AsynchronousException(String, Throwable) - 异常错误 的构造器org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
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
 
AsyncResult - org.apache.flink.streaming.api.operators.async.queue中的接口
Asynchronous result returned by the StreamElementQueue.
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) - 类 的构造器org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
AsyncWatermarkResult - org.apache.flink.streaming.api.operators.async.queue中的接口
AsyncResult subclass for asynchronous result Watermark.
awaitPendingAfterQuiesce() - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
This method can be used after calling ProcessingTimeService.quiesce(), and awaits the completion of currently executing timers.
awaitPendingAfterQuiesce() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
awaitPendingAfterQuiesce() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 

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.
BarrierBuffer - org.apache.flink.streaming.runtime.io中的类
The barrier buffer is CheckpointBarrierHandler that blocks inputs with barriers until all inputs have received the barrier for a given checkpoint.
BarrierBuffer(InputGate, BufferBlocker) - 类 的构造器org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierBuffer(InputGate, BufferBlocker, long) - 类 的构造器org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierTracker - org.apache.flink.streaming.runtime.io中的类
The BarrierTracker keeps track of what checkpoint barriers have been received from which input channels.
BarrierTracker(InputGate) - 类 的构造器org.apache.flink.streaming.runtime.io.BarrierTracker
 
BaseAlignedWindowAssigner - org.apache.flink.streaming.api.windowing.assigners中的类
已过时。
will be removed in a future version. please use other WindowAssigners listed under org.apache.flink.streaming.api.windowing.assigners.
BaseAlignedWindowAssigner(long) - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
已过时。
 
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.
BasePathBucketAssigner<T> - org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners中的类
A BucketAssigner that does not perform any bucketing of files.
BasePathBucketAssigner() - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
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.
BlockingQueueBroker - org.apache.flink.streaming.runtime.io中的类
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams.
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 broadcast 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.
broadcastCheckpointBarrier(long, long, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastCheckpointCancelMarker(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
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) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
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. a stream with broadcast state, with a non-keyed DataStream.
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).
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.
BucketAssigner<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
A BucketAssigner is used with a StreamingFileSink to determine the Bucket each incoming element should be put into.
BucketAssigner.Context - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
Context that the BucketAssigner can use for getting additional data about an input record.
Buckets<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
The manager of the different active buckets in the StreamingFileSink.
BucketsBuilder() - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
 
BufferBlocker - org.apache.flink.streaming.runtime.io中的接口
The buffer blocker takes the buffers and events from a data stream and adds them in a sequence.
BufferEntrySerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
BufferOrEventSequence - org.apache.flink.streaming.runtime.io中的接口
This class represents a sequence of buffers and events which are blocked by CheckpointBarrierHandler.
BufferSerializerConfigSnapshot() - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
BufferSerializerConfigSnapshot(TypeSerializer<T>) - 类 的构造器org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
已过时。
 
BufferSpiller - org.apache.flink.streaming.runtime.io中的类
已过时。
BufferSpiller(IOManager, int) - 类 的构造器org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
Creates a new buffer spiller, spilling to one of the I/O manager's temp directories.
BufferSpiller.SpilledBufferOrEventSequence - org.apache.flink.streaming.runtime.io中的类
已过时。
bufferTimeout - 类 中的变量org.apache.flink.streaming.api.transformations.StreamTransformation
 
build() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Creates the actual policy.
build() - 类 中的静态方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
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.

C

CachedBufferBlocker - org.apache.flink.streaming.runtime.io中的类
The cached buffer blocker takes the buffers and events from a data stream and adds them to a memory queue.
CachedBufferBlocker(int) - 类 的构造器org.apache.flink.streaming.runtime.io.CachedBufferBlocker
Creates a new buffer blocker, caching the buffers or events in memory queue.
CachedBufferBlocker.CachedBufferOrEventSequence - org.apache.flink.streaming.runtime.io中的类
This class represents a sequence of cached buffers and events, created by the CachedBufferBlocker.
cacheFile - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
cancel() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
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.tasks.StreamTask
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancelTask() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
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.
chainingStrategy - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.
CheckpointBarrierHandler - org.apache.flink.streaming.runtime.io中的接口
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
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() - 类 的构造器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.
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.
CheckpointExceptionHandler - org.apache.flink.streaming.runtime.tasks中的接口
Handler for exceptions that happen on checkpointing.
CheckpointExceptionHandlerFactory - org.apache.flink.streaming.runtime.tasks中的类
This factory produces CheckpointExceptionHandler instances that handle exceptions during checkpointing in a StreamTask.
CheckpointExceptionHandlerFactory() - 类 的构造器org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandlerFactory
 
checkpointingLock - 类 中的变量org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
CheckpointingMode - org.apache.flink.streaming.api中的枚举
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures.
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() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierBuffer
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierTracker
 
cleanup() - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferOrEventSequence
Cleans up all the resources held by the sequence.
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
已过时。
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
 
cleanup() - 接口 中的方法org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Cleans up all internally held resources.
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
cleanup() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
clear(ProcessAllWindowFunction<T, R, W>.Context) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
已过时。
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
Deletes any state in the Context when the Window is purged.
clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
Deletes any state in the Context when the Window is purged.
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(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(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 is purged.
clear() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
clear() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
close() - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
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.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.FoldApplyProcessAllWindowFunction
已过时。
 
close() - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
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.AbstractStreamOperator.CountingOutput
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
close() - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
close() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
close() - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
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.BufferBlocker
Cleans up all the resources in the current sequence.
close() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
Cleans up the current spilling channel and file.
close() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker
 
close() - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
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.TimestampsAndPeriodicWatermarksOperator
 
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.StreamTask.AsyncCheckpointRunnable
 
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.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 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(StreamRecord<OUT>) - 类 中的方法org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
 
collect(StreamRecord<OUT>) - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
collect(DataStream<OUT>) - 类 中的静态方法org.apache.flink.streaming.api.datastream.DataStreamUtils
Returns an iterator to iterate over the elements of the DataStream.
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.AbstractStreamOperator.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
Emits a record the side output identified by the given OutputTag.
collect(T) - 类 中的方法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
 
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.
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.
commitCheckpoint(int, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Mark the given checkpoint as completed in the resource.
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(TimestampedFileInputSplit) - 类 中的方法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(Collection<OUT>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
completeExceptionally(Throwable) - 接口 中的方法org.apache.flink.streaming.api.functions.async.ResultFuture
Completes the result future exceptionally with an exception.
completeExceptionally(Throwable) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
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.operators.AbstractStreamOperator
 
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.runtime.tasks.StreamTask
The configuration of this streaming task.
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
 
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
 
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.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> - org.apache.flink.streaming.api.functions.source中的类
The operator that reads the splits received from the preceding ContinuousFileMonitoringFunction.
ContinuousFileReaderOperator(FileInputFormat<OUT>) - 类 的构造器org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
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.
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(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(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.partitioner.BroadcastPartitioner
 
copy() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
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.
CopyingDirectedOutput<OUT> - org.apache.flink.streaming.api.collector.selector中的类
Special version of DirectedOutput that performs a shallow copy of the StreamRecord to ensure that multi-chaining works correctly.
CopyingDirectedOutput(List<OutputSelector<OUT>>, List<? extends Tuple2<? extends Output<StreamRecord<OUT>>, StreamEdge>>) - 类 的构造器org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
 
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(Output<StreamRecord<OUT>>, Counter) - 类 的构造器org.apache.flink.streaming.api.operators.AbstractStreamOperator.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() - 类 中的静态方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Initiates the instantiation of a DefaultRollingPolicy.
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() - 接口 中的方法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.
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.
createCheckpointBarrierHandler(StreamTask<?, ?>, CheckpointingMode, IOManager, InputGate, Configuration) - 类 中的静态方法org.apache.flink.streaming.runtime.io.InputProcessorUtil
 
createCheckpointExceptionHandler(boolean, Environment) - 类 中的方法org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandlerFactory
Returns a CheckpointExceptionHandler that either causes a task to fail completely or to just declines checkpoint on exception, depending on the parameter flag.
createCheckpointExceptionHandlerFactory() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
createExecutionEnvironment() - 接口 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
Creates a StreamExecutionEnvironment from this factory.
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(Collection<InputGate>, Collection<InputGate>) - 类 中的静态方法org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInputGate(InputGate[]) - 类 中的静态方法org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInstance() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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(StreamGraph, JobID) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
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
createLocalEnvironmentWithWebUI(Configuration) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a LocalStreamEnvironment for local program execution that also starts the web monitoring UI.
createMasterTriggerRestoreHook() - 接口 中的方法org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
Creates the hook that should be called by the checkpoint coordinator.
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
 
createRecordWriters(StreamConfig, Environment) - 类 中的静态方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
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.
createStreamTaskStateInitializer() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
currentProcessingTime() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner.Context
Returns the current processing time.
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.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.filesystem.BucketAssigner.Context
Returns the current event-time watermark.
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.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
 

D

DataStream<T> - org.apache.flink.streaming.api.datastream中的类
A DataStream represents a stream of elements of the same type.
DataStream(StreamExecutionEnvironment, StreamTransformation<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStream
Create a new DataStream in the given execution environment with partitioning set to forward by default.
DataStreamSink<T> - org.apache.flink.streaming.api.datastream中的类
A Stream Sink.
DataStreamSink(DataStream<T>, StreamSink<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(SingleOutputStreamOperator<T>) - 类 的构造器org.apache.flink.streaming.api.datastream.DataStreamSource
 
DataStreamUtils - org.apache.flink.streaming.api.datastream中的类
A collection of utilities for DataStreams.
DateTimeBucketAssigner<IN> - org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners中的类
A BucketAssigner that assigns to buckets based on current system time.
DateTimeBucketAssigner() - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with format string "yyyy-MM-dd--HH".
DateTimeBucketAssigner(String) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with the given date/time format string.
DateTimeBucketAssigner(ZoneId) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with format string "yyyy-MM-dd--HH" using the given timezone.
DateTimeBucketAssigner(String, ZoneId) - 类 的构造器org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with the given date/time format string using the given timezone.
days(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of days.
DEFAULT_JOB_NAME - 类 中的静态变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
The default name to use for a streaming job if no other name has been specified.
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_TIMEOUT - 类 中的静态变量org.apache.flink.streaming.api.environment.CheckpointConfig
The default timeout of a checkpoint attempt: 10 minutes.
DefaultRollingPolicy<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies中的类
The default implementation of the RollingPolicy.
DefaultRollingPolicy.PolicyBuilder - org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies中的类
A helper class that holds the configuration properties for the DefaultRollingPolicy.
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(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(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.
DeserializationSchema<T> - org.apache.flink.streaming.util.serialization中的接口
已过时。
Use DeserializationSchema instead.
deserialize(int, byte[]) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
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.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(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.
DirectedOutput<OUT> - org.apache.flink.streaming.api.collector.selector中的类
Wrapping Output that forwards to other Outputs based on a list of OutputSelectors.
DirectedOutput(List<OutputSelector<OUT>>, List<? extends Tuple2<? extends Output<StreamRecord<OUT>>, StreamEdge>>) - 类 的构造器org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
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.
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
 
dispose() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
dispose() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
dispose() - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
dispose() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
dispose() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
dumpStreamingPlanAsJSON(File) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
duplicate() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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

emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
emitLatencyMarker(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
 
emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitStreamStatus(StreamStatus) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
Emitter<OUT> - org.apache.flink.streaming.api.operators.async中的类
Runnable responsible for consuming elements from the given queue and outputting them to the given output/timestampedCollector.
Emitter(Object, Output<StreamRecord<OUT>>, StreamElementQueue, OperatorActions) - 类 的构造器org.apache.flink.streaming.api.operators.async.Emitter
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits the given Watermark.
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.api.operators.Output
Emits a Watermark from an operator.
emitWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
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
Enables checkpoints to be persisted externally.
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.
environment - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
environment - 类 中的变量org.apache.flink.streaming.api.datastream.DataStream
 
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.StreamEdge
 
equals(Object) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
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.transformations.StreamTransformation
 
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.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.streamstatus.StreamStatus
 
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.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
 
execute(String) - 类 中的方法org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Executes the JobGraph of the on a mini cluster of CLusterUtil with a user specified name.
execute(String) - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
execute(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamContextEnvironment
 
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() - 类 中的方法org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
execute(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
executeRemotely(StreamExecutionEnvironment, List<URL>, String, int, Configuration, List<URL>, String, SavepointRestoreSettings) - 类 中的静态方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Executes the job remotely.
executeRemotely(StreamGraph, List<URL>) - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
已过时。
ExternallyInducedSource<T,CD> - org.apache.flink.streaming.api.checkpoint中的接口
Sources that implement this interface do not trigger checkpoints when receiving a trigger message from the checkpoint coordinator, but when their input data/events indicate that a checkpoint should be triggered.
ExternallyInducedSource.CheckpointTrigger - 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.TimestampExtractor
已过时。
Extracts a timestamp from an element.
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
 
ExtractTimestampsOperator<T> - org.apache.flink.streaming.runtime.operators中的类
ExtractTimestampsOperator(TimestampExtractor<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
已过时。
 
extractWatermark(T, long) - 接口 中的方法org.apache.flink.streaming.api.functions.TimestampExtractor
已过时。
Asks the extractor if it wants to emit a watermark now that it has seen the given element.

F

FailingHandler() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
 
failOperator(Throwable) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
failOperator(Throwable) - 接口 中的方法org.apache.flink.streaming.api.operators.async.OperatorActions
Fail the respective stream operator with the given throwable.
FeedbackTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This represents a feedback point in a topology.
FeedbackTransformation(StreamTransformation<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
 
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
 
finishRecoveringContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
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(FlatMapFunction<T, 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.
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.
fold(R, FoldFunction<T, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(R, FoldFunction<T, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
已过时。
will be removed in a future version
fold(R, FoldFunction<T, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.streaming.api.datastream.WindowedStream
FoldApplyAllWindowFunction<W extends Window,T,ACC,R> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
will be removed in a future version
FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
已过时。
 
FoldApplyProcessAllWindowFunction<W extends Window,T,ACC,R> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
will be removed in a future version
FoldApplyProcessAllWindowFunction(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
已过时。
 
FoldApplyProcessWindowFunction<K,W extends Window,T,ACC,R> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
will be removed in a future version
FoldApplyProcessWindowFunction(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
FoldApplyWindowFunction<K,W extends Window,T,ACC,R> - org.apache.flink.streaming.api.functions.windowing中的类
已过时。
will be removed in a future version
FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
已过时。
 
forBulkFormat(Path, BulkWriter.Factory<IN>) - 类 中的静态方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
Creates the builder for a StreamingFileSink with row-encoding format.
forceNonParallel() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism and maximum parallelism of this operator to one.
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.
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.
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(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 set 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
 
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.
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

generate(StreamExecutionEnvironment, List<StreamTransformation<?>>) - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
Generates a StreamGraph by traversing the graph of StreamTransformations starting from the given transformations.
generateSequence(long, long) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains a sequence of numbers.
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.async.queue.AsyncCollectionResult
Return the asynchronous result collection.
get() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
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.
getAccumulatorMap() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getActiveTimerTimestamps() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
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
 
getAlignmentDurationNanos() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierBuffer
 
getAlignmentDurationNanos() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierTracker
 
getAlignmentDurationNanos() - 接口 中的方法org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Gets the time that the latest alignment took, in nanoseconds.
getAllOperators() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getAsyncOperationsThreadPool() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getBindAddress() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
 
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.
getBroadcastStateDescriptor() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
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
 
getBucketId(IN, BucketAssigner.Context) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner
Returns the identifier of the bucket the provided element should be put into.
getBucketId(T, BucketAssigner.Context) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
getBucketId(IN, BucketAssigner.Context) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
getBucketId() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
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.StreamConfig
 
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the buffer timeout of the job.
getBufferTimeout() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the buffer timeout of this StreamTransformation.
getBytesBlocked() - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferBlocker
Gets the number of bytes blocked in the current sequence.
getBytesBlocked() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
Gets the number of bytes written in the current spill file.
getBytesBlocked() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker
 
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
 
getChainEntryPoint() - 类 中的方法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.StreamOperator
 
getChainLength() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
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
 
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.
getCheckpointLock() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Gets the lock object on which all operations that involve data and state mutation have to lock.
getCheckpointMode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getCheckpointMode() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the checkpointing mode.
getCheckpointStorage() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
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
 
getCollector() - 类 中的方法org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
getCollector() - 类 中的方法org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
getCoLocationGroup() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getCoLocationGroupKey() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
NOTE: This is an internal undocumented feature for now.
getCompatibleVersions() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
getConfig() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config object.
getConfiguration() - 类 中的方法org.apache.flink.streaming.api.environment.LocalStreamEnvironment
 
getConfiguration() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getConfiguration() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getContainedTypeSerializer() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
getContainingTask() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getCreationTime() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getCurrentCheckpointId() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierBuffer
Gets the ID defining the current pending, or just completed, checkpoint.
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.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.KeyContext
 
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.ProcessingTimeService
Returns the current processing time.
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.TimestampExtractor
已过时。
Returns the current watermark.
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
 
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().
getDefaultTrigger(StreamExecutionEnvironment) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
已过时。
 
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.
getEnd() - 类 中的方法org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the end timestamp of this window.
getEnvironment() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getEnvironment() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getEvictor() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
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.
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.WindowedStream
 
getExecutionEnvironment() - 类 中的静态方法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.
getExternalizedCheckpointCleanup() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Returns the cleanup behaviour for externalized checkpoints.
getFeedbackEdges() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the list of feedback StreamTransformations.
getFeedbackEdges() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the list of feedback StreamTransformations.
getFieldType() - 类 中的方法org.apache.flink.streaming.util.typeutils.FieldAccessor
Gets the TypeInformation for the type of the field.
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.
getFoldingState(FoldingStateDescriptor<T, ACC>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getFoldingState(FoldingStateDescriptor<T, A>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
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.source.InputFormatSourceFunction
Returns the InputFormat.
getFuture() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
getFuture() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
getFuture() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
getGlobalAggregateManager() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the global aggregate manager for the current job.
getGlobalModificationTime() - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
getHeadOperator() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
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
 
getId() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the unique ID of this StreamTransformation.
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
 
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the input StreamTransformation of this FeedbackTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the input StreamTransformation of this OneInputTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the input StreamTransformation of this SinkTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.SelectTransformation
Returns the input StreamTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
Returns the input StreamTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the input StreamTransformation of this SinkTransformation.
getInput() - 类 中的方法org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the input StreamTransformation.
getInput1() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input StreamTransformation of this TwoInputTransformation.
getInput2() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input StreamTransformation of this TwoInputTransformation.
getInputChannelStatus(int) - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
 
getInputFormat() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getInputs() - 类 中的方法org.apache.flink.streaming.api.transformations.UnionTransformation
Returns the list of input StreamTransformations.
getInputSplitProvider() - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the input split provider associated with the operator.
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.
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 first input.
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, TimerSerializer<K, N>, Triggerable<K, N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
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
 
getJobGraph(JobID) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
Gets the assembled JobGraph with a given job id.
getJobManagerOwnedState() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
getJobName() - 类 中的方法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
 
getKeyedStateManagedFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateRawFuture() - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateStore() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.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.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.
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
 
getLastUpdateTime() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getLeftTimestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getLength() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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
 
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.api.transformations.StreamTransformation
Gets the maximum parallelism for this stream transformation.
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.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
 
getMinResources() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the minimum resource of this stream transformation.
getModificationTime() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getName() - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Gets the name of the current data stream.
getName() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the name of this StreamTransformation.
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
 
getNewIterationNodeId() - 类 中的静态方法org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
getNewNodeId() - 类 中的静态方法org.apache.flink.streaming.api.transformations.StreamTransformation
 
getNext() - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferOrEventSequence
Gets the next BufferOrEvent from the sequence, or null, if the sequence is exhausted.
getNext() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
已过时。
 
getNext() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
 
getNextNonBlocked() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierBuffer
 
getNextNonBlocked() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierTracker
 
getNextNonBlocked() - 接口 中的方法org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Returns the next BufferOrEvent that the operator may consume.
getNonChainedOutputs(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getNumActiveTimers() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getNumberOfExecutionRetries() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
已过时。
This method will be replaced by StreamExecutionEnvironment.getRestartStrategy().
getNumberOfInputs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfOutputs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
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.
getOne() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the TwoInputStreamOperator of this Transformation.
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the StreamSink that is the operator of this SinkTransformation.
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.SourceTransformation
Returns the StreamSource, the operator of this SourceTransformation.
getOperator() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TwoInputStreamOperator of this Transformation.
getOperatorConfig() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorID() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorID() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorID() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
getOperatorId() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
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.
getOperators() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getOperatorStateBackend() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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
 
getOutEdgeIndices() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutEdges(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOutEdges() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutEdgesInOrder(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOutputSelector() - 类 中的方法org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the OutputSelector.
getOutputSelectors(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getOutputSelectors() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getOutputTag() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getOutputTag() - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getOutputType() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the output type of this StreamTransformation as a TypeInformation.
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
 
getParallelism() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the parallelism of this StreamTransformation.
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.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.StreamEdge
 
getPartitioner() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the StreamPartitioner that must be used for partitioning the elements of the input StreamTransformation.
getPendingCommitTransactions() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getPendingTransaction() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
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
 
getPreferredResources() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the preferred resource of this stream transformation.
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.StreamingRuntimeContext
 
getProcessingTimeService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
Returns the ProcessingTimeService responsible for telling the current processing time and registering timers.
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
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getRehashThreshold() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getRestartStrategy() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the specified restart strategy configuration.
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.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
 
getSecondInput() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Returns the BroadcastStream.
getSecondInput() - 类 中的方法org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the second DataStream.
getSelectedNames() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getSelectedNames() - 类 中的方法org.apache.flink.streaming.api.transformations.SelectTransformation
Returns the names of the split streams that this SelectTransformation selects.
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
 
getSerializedStateBackend() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getSerializer() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner
 
getSerializer() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
getSerializer() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
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.
getSinkIDs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSize() - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getSize() - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
已过时。
 
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.transformations.StreamTransformation
Returns the slot sharing group of this transformation.
getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>, long, long) - 类 中的静态方法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
 
getSourceVertex(StreamEdge) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getSplitState() - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
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
 
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.OneInputTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Operation.
getStateKeySelector() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Sink.
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.
getStateKeySerializer(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStateKeySerializer() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
getStateKeyType() - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getStatePartitioner(int, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getStatePartitioner1() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getStatePartitioner2() - 类 中的方法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.streamstatus.StreamStatus
 
getStreamEdges(int, int) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamElement() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
getStreamGraph() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamingPlanAsJSON() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNode(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNodes() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamOperator(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.
getStreamStatus() - 接口 中的方法org.apache.flink.streaming.runtime.streamstatus.StreamStatusProvider
Returns the current stream status.
getStreamStatus() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getStreamStatusMaintainer() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
getStreamTimeCharacteristic() - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the time characteristic.
getSubtaskIndex() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
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
 
getTimeCharacteristic() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTimestamp() - 类 中的方法org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getTimestamp() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
 
getTimestamp() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
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.
getTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.BroadcastStream
 
getTransformation() - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Returns the StreamTransformation 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.
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.CoFeedbackTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.SelectTransformation
 
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.SplitTransformation
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns all transitive predecessor StreamTransformations of this StreamTransformation.
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.
getTypeNumber() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
getTypeSerializerIn1(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn1() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerIn2(ClassLoader) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn2() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
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
 
getUid() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the user-specified ID of this transformation.
getUnit() - 类 中的方法org.apache.flink.streaming.api.windowing.time.Time
Gets the time unit for this policy's time interval.
getUserCodeClassloader() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.
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
 
getUserProvidedNodeHash() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the user provided hash.
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.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
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.InternalTimerServiceSerializationProxy
 
getVersion() - 类 中的方法org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
已过时。
 
getVertexID() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
getVertexIDs() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
getWaitTime() - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the wait time.
getWaitTime() - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the wait time.
getWatermark() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncWatermarkResult
Get the resulting watermark.
getWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
getWatermarkGauge() - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
getWatermarkGauge() - 类 中的方法org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
getWatermarkGauge() - 接口 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain.WatermarkGaugeExposingOutput
 
getWindowAssigner() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getWindowSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
已过时。
 
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
 
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.
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
 
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.AsyncExceptionHandler
Handles an exception thrown by another thread (e.g. a TriggerTask), other than the one executing the main task.
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.
handleStreamStatus(StreamStatus) - 接口 中的方法org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.ValveOutputHandler
 
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.
handleWatermark(Watermark) - 接口 中的方法org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.ValveOutputHandler
 
hasBroadcastVariable(String) - 类 中的方法org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
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.StreamEdge
 
hashCode() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
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.transformations.StreamTransformation
 
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.streamrecord.LatencyMarker
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
hashCode() - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
hasNext() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
Returns true if the DataStream has more elements.
hasTimestamp() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
 
hasTimestamp() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
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.
headOperator - 类 中的变量org.apache.flink.streaming.runtime.tasks.StreamTask
the head operator that consumes the input streams of this task.
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
 
id - 类 中的变量org.apache.flink.streaming.api.transformations.StreamTransformation
 
idCounter - 类 中的静态变量org.apache.flink.streaming.api.transformations.StreamTransformation
 
IDLE - 类 中的静态变量org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
IDLE_STATUS - 类 中的静态变量org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
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
 
IngestionTimeExtractor<T> - org.apache.flink.streaming.api.functions中的类
A timestamp assigner that assigns timestamps based on the machine's wall clock.
IngestionTimeExtractor() - 类 的构造器org.apache.flink.streaming.api.functions.IngestionTimeExtractor
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
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
 
init() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
initializeContextEnvironment(StreamExecutionEnvironmentFactory) - 类 中的静态方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
initializeState(FunctionInitializationContext) - 接口 中的方法org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
This method is called when the parallel function instance is created during distributed execution.
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.FromElementsFunction
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
initializeState(FunctionInitializationContext) - 类 中的方法org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
initializeState() - 类 中的方法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(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() - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
Provides a context to initialize all state in the operator.
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
initializeUserContext() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
InputChannelStatus() - 类 的构造器org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
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.
InputProcessorUtil - org.apache.flink.streaming.runtime.io中的类
Utility for creating CheckpointBarrierHandler based on checkpoint mode for StreamInputProcessor and StreamTwoInputProcessor.
InputProcessorUtil() - 类 的构造器org.apache.flink.streaming.runtime.io.InputProcessorUtil
 
inputStream1 - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStream2 - 类 中的变量org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStreamStatus(StreamStatus, int) - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a StreamStatus into the valve.
inputWatermark(Watermark, int) - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a Watermark into the valve.
INSTANCE - 类 中的静态变量org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
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.
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(InternalTimeServiceManager<K>, ClassLoader, int) - 类 的构造器org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
Constructor to use when restoring timer services.
InternalTimerServiceSerializationProxy(InternalTimeServiceManager<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 available to all operators extending the AbstractStreamOperator.
internalTimeServiceManager(AbstractKeyedStateBackend<K>, KeyContext, Iterable<KeyGroupStatePartitionStreamProvider>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
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.
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.BufferEntrySerializerSnapshot<T> - org.apache.flink.streaming.api.operators.co中的类
A TypeSerializerSnapshot for 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.
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.experimental.CollectSink
 
invoke() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isActive() - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isBroadcast() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
isBroadcast() - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
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
 
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.
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.
isDone() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
True if the stream element queue entry has been completed; otherwise false.
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.io.BarrierBuffer
 
isEmpty() - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierTracker
 
isEmpty() - 接口 中的方法org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Checks if the barrier handler has buffered any data internally.
isEmpty() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Checks whether the map is empty.
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.BaseAlignedWindowAssigner
已过时。
 
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.
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
 
isFailOnCheckpointingErrors() - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
This determines the behaviour of tasks if there is an error in their local checkpointing.
isFire() - 枚举 中的方法org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isFlushAlwaysEnabled() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
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.
isIdle() - 类 中的方法org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isImmutableType() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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
 
isIterative() - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
isLatencyMarker() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a record.
isOne() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
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, the states provided by this context are restored from a checkpoint/savepoint.
isResultCollection() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncResult
True fi the async result is a collection of output elements; otherwise false.
isResultCollection() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
isRunning() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
isSameSlotSharingGroup(StreamNode) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
isStreamStatus() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a stream status.
isTerminated() - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Returns true if the service has been shut down, false otherwise.
isTerminated() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
isTerminated() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
isTwo() - 类 中的方法org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isWatermark() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.AsyncResult
True if the async result is a Watermark; otherwise false.
isWatermark() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
isWatermark() - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark.
isWatermarkAligned - 类 中的变量org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
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.
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.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.
keyBy(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - 类 中的方法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
Partitions the operator state of a DataStream by the given key positions.
keyBy(String...) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Partitions the operator state of a DataStream using field expressions.
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, ?>, KeySelector<F, ?>) - 类 中的方法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中的接口
Inteface 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. a stream with broadcast state, with a KeyedStream.
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).
KeyedCoProcessOperator<K,IN1,IN2,OUT> - org.apache.flink.streaming.api.operators.co中的类
A StreamOperator for executing keyed CoProcessFunctions.
KeyedCoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
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) - 类 中的方法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.
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.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.
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
已过时。
 
ListCheckpointed<T extends Serializable> - org.apache.flink.streaming.api.checkpoint中的接口
This interface can be implemented by functions that want to store state in checkpoints.
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.runtime.operators.CheckpointCommitter
 
LOG - 类 中的静态变量org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
LoggingHandler() - 类 的构造器org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
 
lowerBoundExclusive() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the lower bound to be exclusive.

M

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(MapFunction<T, 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.
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.
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_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.
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(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.
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.
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.
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 a WatermarkGauge pair.
MinWatermarkGauge(WatermarkGauge, WatermarkGauge) - 类 的构造器org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
 
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.

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.
name - 类 中的变量org.apache.flink.streaming.api.transformations.StreamTransformation
 
NeverTrigger() - 类 的构造器org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
next() - 类 中的方法org.apache.flink.streaming.experimental.SocketStreamIterator
Returns the next element of the DataStream.
nextValue(V) - 接口 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called for each value found for the current key.
NO_VERSION - 类 中的静态变量org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
nonParallel - 类 中的变量org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Indicate this is a non-parallel operator and cannot set a non-1 degree of parallelism.
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.AbstractUdfStreamOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
notifyCheckpointComplete(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.AbstractStreamOperator
 
numEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers(N) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
numLateRecordsDropped - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
numProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
numProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers(N) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers() - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 

O

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, Time) - 类 中的静态方法org.apache.flink.streaming.api.windowing.assigners.SlidingTimeWindows
已过时。
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) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.streaming.api.windowing.assigners.TumblingTimeWindows
已过时。
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>) - 类 中的静态方法org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
Creates a new purging trigger from the given Trigger.
OnCheckpointRollingPolicy<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies中的类
A RollingPolicy which rolls on every checkpoint.
onComplete(Consumer<StreamElementQueueEntry<T>>, Executor) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
Register the given complete function to be called once this queue entry has been completed.
onCompleteHandler(StreamElementQueueEntry<?>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
Callback for onComplete events for the given stream element queue entry.
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.
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, ProcessingTimeService) - 类 的构造器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 StreamTransformation.
OneInputTransformation(StreamTransformation<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.
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(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
 
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.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, 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
 
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
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(long) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
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, 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.ExtractTimestampsOperator
已过时。
 
onProcessingTime(long) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
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
 
onProcessingTime(long) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeCallback
This method is invoked with the timestamp for which the trigger was scheduled.
onTimer(long, CoProcessFunction<IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - 类 中的方法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, 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.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.filesystem.StreamingFileSink
 
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(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.FoldApplyAllWindowFunction
已过时。
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
已过时。
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
open(Configuration) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
已过时。
 
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.AbstractUdfStreamOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
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.KeyedProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.ProcessOperator
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamFlatMap
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamGroupedFold
已过时。
 
open() - 类 中的方法org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
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.io.BufferOrEventSequence
Initializes the sequence for reading.
open() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
已过时。
This method needs to be called before the first call to BufferSpiller.SpilledBufferOrEventSequence.getNext().
open() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
 
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.ExtractTimestampsOperator
已过时。
 
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
open() - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
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
 
OperatorActions - org.apache.flink.streaming.api.operators.async中的接口
Interface for StreamOperator actions.
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>, List<RecordWriter<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.WatermarkGaugeExposingOutput<T> - org.apache.flink.streaming.runtime.tasks中的接口
An Output that measures the last emitted watermark with a WatermarkGauge.
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>>) - 类 的构造器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 - org.apache.flink.streaming.api.operators.async.queue中的类
Ordered StreamElementQueue implementation.
OrderedStreamElementQueue(int, Executor, OperatorActions) - 类 的构造器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
Add an AsyncWaitOperator.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
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.collector.selector - 程序包 org.apache.flink.streaming.api.collector.selector
 
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.sink.filesystem.bucketassigners - 程序包 org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners
 
org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies - 程序包 org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
 
org.apache.flink.streaming.api.functions.source - 程序包 org.apache.flink.streaming.api.functions.source
 
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.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.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.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.streamstatus - 程序包 org.apache.flink.streaming.runtime.streamstatus
 
org.apache.flink.streaming.runtime.tasks - 程序包 org.apache.flink.streaming.runtime.tasks
This package contains classes that realize streaming tasks.
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.keys - 程序包 org.apache.flink.streaming.util.keys
 
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.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.AbstractStreamOperator
 
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
 
OutputFormatSinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the BucketingSink for writing to files from a streaming program.
OutputFormatSinkFunction(OutputFormat<IN>) - 类 的构造器org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
outputMap - 类 中的变量org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
OutputSelector<OUT> - org.apache.flink.streaming.api.collector.selector中的接口
outputSelectors - 类 中的变量org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
outputType - 类 中的变量org.apache.flink.streaming.api.transformations.StreamTransformation
 
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.

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.
PartFileInfo<BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
An interface exposing the information concerning the current (open) part file that is necessary to the RollingPolicy in order to determine if it should roll the part file or not.
partitionCustom(Partitioner<K>, int) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, KeySelector<T, K>) - 类 中的方法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(StreamTransformation<T>, StreamPartitioner<T>) - 类 的构造器org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
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
已过时。
 
peekBlockingly() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
peekBlockingly() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Peek at the head of the queue and return the first completed AsyncResult.
peekBlockingly() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
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
 
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
 
poll() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
poll() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Poll the first completed AsyncResult from the head of this queue.
poll() - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
preCommit(TXN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Pre commit previously created transaction.
PREDECESSORS - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.OperatorChain
 
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).
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 output stream (stderr).
printToErr(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output 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<KS, 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<KS, 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(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<T, R, W>.Context, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
已过时。
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
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.
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.
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.
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<TimestampedFileInputSplit>) - 类 中的方法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.KeyedProcessOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
已过时。
 
processElement(StreamRecord<IN>) - 接口 中的方法org.apache.flink.streaming.api.operators.OneInputStreamOperator
Processes one element that arrived at this operator.
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.StreamGroupedFold
已过时。
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
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<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
已过时。
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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(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.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(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.TwoInputStreamOperator
Processes one element that arrived on the second input of this two-input operator.
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).
ProcessingTimeCallback - org.apache.flink.streaming.runtime.tasks中的接口
Interface for processing-time callbacks that can be registered at a ProcessingTimeService.
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.
ProcessingTimeService() - 类 的构造器org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
 
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
 
processInput() - 类 中的方法org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
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.AbstractStreamOperator
 
processLatencyMarker(LatencyMarker) - 接口 中的方法org.apache.flink.streaming.api.operators.OneInputStreamOperator
 
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.AbstractStreamOperator
 
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.OneInputStreamOperator
Processes a Watermark.
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.ExtractTimestampsOperator
已过时。
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the AssignerWithPeriodicWatermarks to emit watermarks from here).
processWatermark(Watermark) - 类 中的方法org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the AssignerWithPunctuatedWatermarks to emit watermarks from here).
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.
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.
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.
PurgingTrigger<T,W extends Window> - org.apache.flink.streaming.api.windowing.triggers中的类
A trigger that can turn any Trigger into a purging Trigger.
put(StreamElementQueueEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
put(StreamElementQueueEntry<T>) - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Put the given element in the queue if capacity is left.
put(StreamElementQueueEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
put(K, V) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts the given value, mapped under the given key.
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.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, ProcessingTimeCallback) only a "mock" future.
quiesce() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
quiesce() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 

R

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
Reads the contents of the user-specified filePath based on the given FileInputFormat.
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
Reads the contents of the user-specified filePath based on the given FileInputFormat.
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the contents of the user-specified filePath based on the given FileInputFormat.
readFileStream(String, long, FileMonitoringFunction.WatchType) - 类 中的方法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
 
readTextFile(String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such line.
readTextFile(String, String) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such line.
readTimersSnapshot(DataInputView) - 接口 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
Reads a timers snapshot from the provided input view.
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
 
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, StreamStatusProvider) - 类 的构造器org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
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
 
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
 
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.
registerCheckpointEventHandler(AbstractInvokable) - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierBuffer
 
registerCheckpointEventHandler(AbstractInvokable) - 类 中的方法org.apache.flink.streaming.runtime.io.BarrierTracker
 
registerCheckpointEventHandler(AbstractInvokable) - 接口 中的方法org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Registers the task be notified once all checkpoint barriers have been received for a checkpoint.
registerCleanupTimer(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Registers a timer to cleanup the content of the window.
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(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
 
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(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
 
registerTimer(long, ProcessingTimeCallback) - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed when (processing) time is timestamp.
registerTimer(long, 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, 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.
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.
releaseOutputs() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
This method releases all resources of the record writer output.
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.
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.StreamSink
 
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
 
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.TimestampedFileInputSplit
Sets the state of the split to null.
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
已过时。
 
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.
restoreStateForKeyGroup(InputStream, int, ClassLoader) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
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.
retireWindow(W) - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Removes the given window from the set of in-flight windows.
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.
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
 
RollingPolicy<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的接口
The policy based on which a Bucket in the StreamingFileSink rolls its currently open part file and opens a new one.
rollOverReusingResources() - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferBlocker
Starts a new sequence of buffers and event reusing the same resources and returns the current sequence of buffers for reading.
rollOverReusingResources() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
NOTE: The BufferOrEventSequences created by this method all reuse the same reading memory (to reduce overhead) and can consequently not be read concurrently with each other.
rollOverReusingResources() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker
It is never reusing resources and is defaulting to CachedBufferBlocker.rollOverWithoutReusingResources().
rollOverWithoutReusingResources() - 接口 中的方法org.apache.flink.streaming.runtime.io.BufferBlocker
Starts a new sequence of buffers and event without reusing the same resources and returns the current sequence of buffers for reading.
rollOverWithoutReusingResources() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller
已过时。
The BufferOrEventSequence returned by this method is safe for concurrent consumption with any previously returned sequence.
rollOverWithoutReusingResources() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker
 
run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
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() - 类 中的方法org.apache.flink.streaming.api.operators.async.Emitter
 
run(Object, StreamStatusMaintainer) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
run(Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>) - 类 中的方法org.apache.flink.streaming.api.operators.StreamSource
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
run() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 

S

scheduleAtFixedRate(ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed repeatedly at a fixed rate.
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
seconds(long) - 类 中的静态方法org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of seconds.
select(OUT) - 接口 中的方法org.apache.flink.streaming.api.collector.selector.OutputSelector
Method for selecting output names for the emitted objects when using the SingleOutputStreamOperator.split(org.apache.flink.streaming.api.collector.selector.OutputSelector<T>) method.
select(String...) - 类 中的方法org.apache.flink.streaming.api.datastream.SplitStream
已过时。
Sets the output names for which the next operator will receive values.
selectAllOutputs - 类 中的变量org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
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.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
 
selectOutputs(StreamRecord<OUT>) - 类 中的方法org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
SelectTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This transformation represents a selection of only certain upstream elements.
SelectTransformation(StreamTransformation<T>, List<String>) - 类 的构造器org.apache.flink.streaming.api.transformations.SelectTransformation
Creates a new SelectionTransformation from the given input that only selects the streams with the selected names.
sendValues(Iterable<IN>, long, long) - 类 中的方法org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
Write the given element into the backend.
SerializationSchema<T> - org.apache.flink.streaming.util.serialization中的接口
已过时。
Use SerializationSchema instead.
serialize(String) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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(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.
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
 
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.StreamConfig
 
setBufferTimeout(Integer, long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setBufferTimeout(Long) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setBufferTimeout(long) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Set the buffer timeout of this StreamTransformation.
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
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setChainingStrategy(ChainingStrategy) - 接口 中的方法org.apache.flink.streaming.api.operators.StreamOperator
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.PartitionTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.SelectTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
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.SplitTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the chaining strategy of this StreamTransformation.
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.streaming.api.transformations.UnionTransformation
 
setChainStart() - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
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
 
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
 
setCoLocationGroupKey(String) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
NOTE: This is an internal undocumented feature for now.
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
 
setContext(Optional<CONTEXT>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setCurrentKey(Object) - 接口 中的方法org.apache.flink.streaming.api.operators.KeyContext
 
setCurrentTime(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
setCurrentWatermark(long) - 类 中的方法org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
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().
setEventTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setFailOnCheckpointingErrors(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the expected behaviour for tasks in case that they encounter an error in their checkpointing procedure.
setForceCheckpointing(boolean) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
已过时。
This will be removed once iterations properly participate in checkpointing.
setInPhysicalEdges(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setInputFormat(Integer, InputFormat<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setInputFormat(InputFormat<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
已过时。
 
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
 
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
 
setKeyContextElement1(StreamRecord) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.StreamOperator
 
setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeySerializerSnapshot(TypeSerializerSnapshot<K>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
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
 
setMaxParallelism(int) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the maximum parallelism for this stream transformation.
setMinPauseBetweenCheckpoints(long) - 类 中的方法org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the minimal pause between checkpointing attempts.
setName(String) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Changes the name of this StreamTransformation.
setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N>) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setNonChainedOutputs(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
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.
setNumberOfInputs(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
 
setOperator(Integer, StreamOperator<OUT>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setOperator(StreamOperator<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
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
 
setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - 类 中的方法org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setOutEdges(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOutEdgesInOrder(List<StreamEdge>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOutputSelectors(List<OutputSelector<?>>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
setOutputType(TypeInformation<R>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
已过时。
 
setOutputType(TypeInformation<R>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
已过时。
 
setOutputType(TypeInformation<R>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
setOutputType(TypeInformation<R>, ExecutionConfig) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
已过时。
 
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.StreamGroupedFold
已过时。
 
setOutputType(TypeInformation<T>) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Tries to fill in the type information.
setOutputType(Function, TypeInformation<T>, ExecutionConfig) - 类 中的静态方法org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
setOutType(Integer, TypeInformation<OUT>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
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
 
setParallelism(int) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the parallelism of this StreamTransformation.
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
 
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
 
setResources(ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the minimum and preferred resources for this stream transformation.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the restart strategy configuration.
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.FoldApplyProcessAllWindowFunction
已过时。
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
已过时。
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
setSerializerIn1(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSerializerIn2(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSerializerOut(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSerializersFrom(Integer, Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setSlotSharingGroup(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setSlotSharingGroup(String) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the slot sharing group of this transformation.
setSplitState(Serializable) - 类 中的方法org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Sets the state of the split.
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the state backend that describes how to store and checkpoint operator state.
setStateBackend(AbstractStateBackend) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStateBackend(StateBackend) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setStateKeySelector(KeySelector<IN, ?>) - 类 中的方法org.apache.flink.streaming.api.transformations.OneInputTransformation
Sets the KeySelector that must be used for partitioning keyed state of this operation.
setStateKeySelector(KeySelector<T, ?>) - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
Sets the KeySelector that must be used for partitioning keyed state of this Sink.
setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - 类 中的方法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.OneInputTransformation
 
setStateKeyType(TypeInformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.SinkTransformation
 
setStateKeyType(TypeInformation<?>) - 类 中的方法org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setStatePartitioner(int, KeySelector<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStatePartitioner1(KeySelector<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setStatePartitioner2(KeySelector<?, ?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setStreamOperator(StreamOperator<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setStreamTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the time characteristic for all streams create from this environment, e.g., processing time, event time, or ingestion time.
setTimeCharacteristic(TimeCharacteristic) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTimestamp(StreamRecord<?>) - 类 中的方法org.apache.flink.streaming.api.operators.TimestampedCollector
 
setTimestamp(long) - 类 中的方法org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
setTransactionTimeout(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Sets the transaction timeout.
setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamGraph
 
setTypeSerializerIn1(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerIn2(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerOut(TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
setUid(String) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets an ID for this StreamTransformation.
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.
setUidHash(String) - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
Sets an user provided hash for this operator.
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.StreamOperator
Initializes the operator.
setup(int) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
setup(int) - 类 中的方法org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
setUserHash(String) - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
setVertexID(Integer) - 类 中的方法org.apache.flink.streaming.api.graph.StreamConfig
 
SHIP_STRATEGY - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll on every checkpoint.
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll based on its current state, e.g. its size.
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - 接口 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll based on a time condition.
shuffle() - 类 中的方法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
 
shutdownAndAwaitPending(long, TimeUnit) - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Shuts down and clean up the timer service provider hard and immediately.
shutdownAndAwaitPending(long, TimeUnit) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownAndAwaitPending(long, TimeUnit) - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Shuts down and clean up the timer service provider hard and immediately.
shutdownService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownService() - 类 中的方法org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownServiceUninterruptible(long) - 类 中的方法org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
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
 
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.
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.
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(StreamTransformation<?>, OutputTag<T>) - 类 的构造器org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
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
 
SimpleVersionedStringSerializer - org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners中的类
A SimpleVersionedSerializer implementation for Strings.
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, StreamTransformation<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<T> - org.apache.flink.streaming.api.functions.sink中的接口
Context that SinkFunctions can use for getting additional data about an input record.
SinkTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This Transformation represents a Sink.
SinkTransformation(StreamTransformation<T>, String, StreamSink<T>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.SinkTransformation
Creates a new SinkTransformation from the given input StreamTransformation.
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.io.BufferOrEventSequence
Gets the size of the sequence.
size() - 类 中的方法org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
已过时。
 
size() - 类 中的方法org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
 
size() - 类 中的方法org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the number of elements currently in the map.
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.
SlidingTimeWindows - org.apache.flink.streaming.api.windowing.assigners中的类
已过时。
slotSharingGroup(String) - 类 中的方法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.
snapshotConfiguration() - 类 中的方法org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
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(FunctionSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
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.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(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
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.runtime.operators.GenericWriteAheadSink
 
snapshotStateForKeyGroup(DataOutputView, int) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
snapshotTimersForKeyGroup(int) - 类 中的方法org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx.
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
 
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.
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<T> - org.apache.flink.streaming.api.transformations中的类
This represents a Source.
SourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.SourceTransformation
Creates a new SourceTransformation from the given operator.
split(OutputSelector<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
已过时。
Please use side ouput instead.
split(OutputSelector<T>) - 类 中的方法org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
SplitStream<OUT> - org.apache.flink.streaming.api.datastream中的类
已过时。
SplitStream(DataStream<OUT>, OutputSelector<OUT>) - 类 的构造器org.apache.flink.streaming.api.datastream.SplitStream
已过时。
 
SplitTransformation<T> - org.apache.flink.streaming.api.transformations中的类
This transformation represents a split of one DataStream into several DataStreams using an OutputSelector.
SplitTransformation(StreamTransformation<T>, OutputSelector<T>) - 类 的构造器org.apache.flink.streaming.api.transformations.SplitTransformation
Creates a new SplitTransformation from the given input and OutputSelector.
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.
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.
StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - 类 的构造器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.streamstatus.StreamStatus
 
StatusWatermarkValve - org.apache.flink.streaming.runtime.streamstatus中的类
A StatusWatermarkValve embodies the logic of how Watermark and StreamStatus are propagated to downstream outputs, given a set of one or multiple input channels that continuously receive them.
StatusWatermarkValve(int, StatusWatermarkValve.ValveOutputHandler) - 类 的构造器org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Returns a new StatusWatermarkValve.
StatusWatermarkValve.InputChannelStatus - org.apache.flink.streaming.runtime.streamstatus中的类
An InputChannelStatus keeps track of an input channel's last watermark, stream status, and whether or not the channel's current watermark is aligned with the overall watermark output from the valve.
StatusWatermarkValve.ValveOutputHandler - org.apache.flink.streaming.runtime.streamstatus中的接口
Usages of StatusWatermarkValve should implement a ValveOutputHandler to handle watermark and stream status outputs from the valve.
STEPS - 类 中的静态变量org.apache.flink.streaming.api.graph.JSONGenerator
 
stop() - 类 中的方法org.apache.flink.streaming.api.operators.async.Emitter
 
stop() - 类 中的方法org.apache.flink.streaming.api.operators.StoppableStreamSource
Marks the source a stopped and calls StoppableFunction.stop() on the user function.
stop() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction> - org.apache.flink.streaming.runtime.tasks中的类
Stoppable task for executing stoppable streaming sources.
StoppableSourceStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction> - org.apache.flink.streaming.api.operators中的类
StoppableStreamSource takes a SourceFunction that implements StoppableFunction.
StoppableStreamSource(SRC) - 类 的构造器org.apache.flink.streaming.api.operators.StoppableStreamSource
Takes a SourceFunction that implements StoppableFunction.
StreamConfig - org.apache.flink.streaming.api.graph中的类
Internal configuration for a StreamOperator.
StreamConfig(Configuration) - 类 的构造器org.apache.flink.streaming.api.graph.StreamConfig
 
StreamContextEnvironment - org.apache.flink.streaming.api.environment中的类
Special StreamExecutionEnvironment that will be used in cases where the CLI client or testing utilities create a StreamExecutionEnvironment that should be used when StreamExecutionEnvironment.getExecutionEnvironment() is called.
StreamContextEnvironment(ContextEnvironment) - 类 的构造器org.apache.flink.streaming.api.environment.StreamContextEnvironment
 
StreamEdge - org.apache.flink.streaming.api.graph中的类
An edge in the streaming topology.
StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>, OutputTag) - 类 的构造器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 - org.apache.flink.streaming.api.operators.async.queue中的接口
Interface for blocking stream element queues for the AsyncWaitOperator.
StreamElementQueueEntry<T> - org.apache.flink.streaming.api.operators.async.queue中的类
Entry class for the StreamElementQueue.
StreamElementQueueEntry(StreamElement) - 类 的构造器org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
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
 
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
 
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(StreamExecutionEnvironment) - 类 的构造器org.apache.flink.streaming.api.graph.StreamGraph
 
StreamGraphGenerator - org.apache.flink.streaming.api.graph中的类
A generator that generates a StreamGraph from a graph of StreamTransformations.
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
 
StreamGroupedFold<IN,OUT,KEY> - org.apache.flink.streaming.api.operators中的类
已过时。
will be removed in a future version
StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - 类 的构造器org.apache.flink.streaming.api.operators.StreamGroupedFold
已过时。
 
StreamGroupedReduce<IN> - org.apache.flink.streaming.api.operators中的类
A StreamOperator for executing a ReduceFunction on a KeyedStream.
StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - 类 的构造器org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
StreamingFileSink<IN> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
Sink that emits its input elements to FileSystem files within buckets.
StreamingFileSink(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.
StreamingFileSink.BucketsBuilder<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
StreamingFileSink.BulkFormatBuilder<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
A builder for configuring the sink for bulk-encoding formats, e.g.
StreamingFileSink.RowFormatBuilder<IN,BucketID> - org.apache.flink.streaming.api.functions.sink.filesystem中的类
A builder for configuring the sink for row-wise encoding formats.
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
 
StreamInputProcessor<IN> - org.apache.flink.streaming.runtime.io中的类
Input reader for OneInputStreamTask.
StreamInputProcessor(InputGate[], TypeSerializer<IN>, StreamTask<?, ?>, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, OneInputStreamOperator<IN, ?>, TaskIOMetricGroup, WatermarkGauge) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
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
 
StreamNode - org.apache.flink.streaming.api.graph中的类
Class representing the operators in the streaming programs, with all their properties.
StreamNode(StreamExecutionEnvironment, Integer, String, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - 类 的构造器org.apache.flink.streaming.api.graph.StreamNode
 
StreamOperator<OUT> - org.apache.flink.streaming.api.operators中的接口
Basic interface for stream operators.
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, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup) - 接口 中的方法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, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup) - 类 中的方法org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamPartitioner<T> - org.apache.flink.streaming.runtime.partitioner中的类
A special ChannelSelector for use in streaming programs.
StreamPartitioner() - 类 的构造器org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
StreamPlanEnvironment - org.apache.flink.streaming.api.environment中的类
A special StreamExecutionEnvironment that is used in the web frontend when generating a user-inspectable graph of a streaming job.
StreamPlanEnvironment(ExecutionEnvironment) - 类 的构造器org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
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.
StreamRecordQueueEntry<OUT> - org.apache.flink.streaming.api.operators.async.queue中的类
StreamRecordQueueEntry(StreamRecord<?>) - 类 的构造器org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
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) - 类 的构造器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
 
streamStatus - 类 中的变量org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
StreamStatus - org.apache.flink.streaming.runtime.streamstatus中的类
A Stream Status element informs stream tasks whether or not they should continue to expect records and watermarks from the input stream that sent them.
StreamStatus(int) - 类 的构造器org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
StreamStatusMaintainer - org.apache.flink.streaming.runtime.streamstatus中的接口
Interface that allows toggling the current StreamStatus as well as retrieving it.
StreamStatusProvider - org.apache.flink.streaming.runtime.streamstatus中的接口
Interface for retrieving the current StreamStatus.
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, ProcessingTimeService) - 类 的构造器org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask.AsyncCheckpointRunnable - org.apache.flink.streaming.runtime.tasks中的类
This runnable executes the asynchronous parts of all involved backend snapshots for the subtask.
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.
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, ProcessingTimeService) - 类 的构造器org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamTransformation<T> - org.apache.flink.streaming.api.transformations中的类
A StreamTransformation represents the operation that creates a DataStream.
StreamTransformation(String, TypeInformation<T>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.StreamTransformation
Creates a new StreamTransformation with the given name, output type and parallelism.
StreamTwoInputProcessor<IN1,IN2> - org.apache.flink.streaming.runtime.io中的类
Input reader for TwoInputStreamTask.
StreamTwoInputProcessor(Collection<InputGate>, Collection<InputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>, TwoInputStreamTask<IN1, IN2, ?>, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, TwoInputStreamOperator<IN1, IN2, ?>, TaskIOMetricGroup, WatermarkGauge, WatermarkGauge) - 类 的构造器org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
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
 
SystemProcessingTimeService - org.apache.flink.streaming.runtime.tasks中的类
A ProcessingTimeService which assigns as current processing time the result of calling System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor.
SystemProcessingTimeService(AsyncExceptionHandler, Object) - 类 的构造器org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
SystemProcessingTimeService(AsyncExceptionHandler, Object, ThreadFactory) - 类 的构造器org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 

T

TestProcessingTimeService - org.apache.flink.streaming.runtime.tasks中的类
This is a 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.
TimeCharacteristic - org.apache.flink.streaming.api中的枚举
The time characteristic defines how the system determines time for time-dependent order and operations that depend on time (such as time windows).
timeDomain() - 类 中的方法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.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.
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.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.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 ProcessingTimeService used to define the current processing time (default = System.currentTimeMillis()) and register timers for tasks to be executed in the future.
timeServiceManager - 类 中的变量org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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.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.filesystem.BucketAssigner.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.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中的接口
A TimestampAssigner assigns event time timestamps to elements.
TimestampedCollector<T> - org.apache.flink.streaming.api.operators中的类
Wrapper around an Output for user functions that expect a Collector.
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中的类
An extended FileInputSplit that also includes information about: The modification time of the file this split belongs to.
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.
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.
TimestampExtractor<T> - org.apache.flink.streaming.api.functions中的接口
已过时。
TimestampsAndPeriodicWatermarksOperator<T> - org.apache.flink.streaming.runtime.operators中的类
A stream operator that extracts timestamps from stream elements and generates periodic watermarks.
TimestampsAndPeriodicWatermarksOperator(AssignerWithPeriodicWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
TimestampsAndPunctuatedWatermarksOperator<T> - org.apache.flink.streaming.runtime.operators中的类
A stream operator that extracts timestamps from stream elements and generates watermarks based on punctuation elements.
TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T>) - 类 的构造器org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
 
timeWindow(Time) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into tumbling time windows.
timeWindow(Time, Time) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into sliding time windows.
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
Windows this DataStream into tumbling time windows.
timeWindowAll(Time, Time) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into sliding time windows.
TimeWindowSerializerSnapshot() - 类 的构造器org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer.TimeWindowSerializerSnapshot
 
toggleStreamStatus(StreamStatus) - 接口 中的方法org.apache.flink.streaming.runtime.streamstatus.StreamStatusMaintainer
Toggles the current stream status.
toggleStreamStatus(StreamStatus) - 类 中的方法org.apache.flink.streaming.runtime.tasks.OperatorChain
 
toMilliseconds() - 类 中的方法org.apache.flink.streaming.api.windowing.time.Time
Converts the time interval to milliseconds.
toString() - 类 中的方法org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
toString() - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
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
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamEdge
 
toString() - 类 中的方法org.apache.flink.streaming.api.graph.StreamNode
 
toString() - 类 中的方法org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
toString() - 类 中的方法org.apache.flink.streaming.api.transformations.StreamTransformation
 
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.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.BarrierBuffer
 
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.streamstatus.StreamStatus
 
toString() - 异常错误 中的方法org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
toString() - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
toString() - 异常错误 中的方法org.apache.flink.streaming.runtime.tasks.TimerException
 
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>, 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>, OneInputStreamOperator<T, R>) - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream
 
transformation - 类 中的变量org.apache.flink.streaming.api.datastream.DataStream
 
transformations - 类 中的变量org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
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.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.
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - 类 中的方法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.
tryHandleCheckpointException(CheckpointMetaData, Exception) - 接口 中的方法org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandler
Offers the exception for handling.
tryPut(StreamElementQueueEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
tryPut(StreamElementQueueEntry<T>) - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Try to put the given element in the queue.
tryPut(StreamElementQueueEntry<T>) - 类 中的方法org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
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) - 类 的构造器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.
TumblingTimeWindows - org.apache.flink.streaming.api.windowing.assigners中的类
已过时。
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.
TwoInputStreamTask<IN1,IN2,OUT> - org.apache.flink.streaming.runtime.tasks中的类
TwoInputStreamTask(Environment) - 类 的构造器org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
TwoInputTransformation<IN1,IN2,OUT> - org.apache.flink.streaming.api.transformations中的类
This Transformation represents the application of a TwoInputStreamOperator to two input StreamTransformations.
TwoInputTransformation(StreamTransformation<IN1>, StreamTransformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - 类 的构造器org.apache.flink.streaming.api.transformations.TwoInputTransformation
Creates a new TwoInputTransformation from the given inputs and operator.
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.
typeUsed - 类 中的变量org.apache.flink.streaming.api.transformations.StreamTransformation
 

U

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.
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.
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 StreamTransformations.
UnionTransformation(List<StreamTransformation<T>>) - 类 的构造器org.apache.flink.streaming.api.transformations.UnionTransformation
Creates a new UnionTransformation from the given input StreamTransformations.
UnorderedStreamElementQueue - org.apache.flink.streaming.api.operators.async.queue中的类
Unordered implementation of the StreamElementQueue.
UnorderedStreamElementQueue(int, Executor, OperatorActions) - 类 的构造器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
Add an AsyncWaitOperator.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - 类 中的静态方法org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
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
 
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
已过时。
 
UPPER_BOUND_MAX_PARALLELISM - 类 中的静态变量org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
upperBoundExclusive() - 类 中的方法org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the upper bound to be exclusive.
userContext - 类 中的变量org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
userFunction - 类 中的变量org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
The user function.

V

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.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.windowing.triggers.TriggerResult
返回带有指定名称的该类型的枚举常量。
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.operators.async.queue.OrderedStreamElementQueue
 
values() - 接口 中的方法org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Return the collection of StreamElementQueueEntry currently contained in this queue.
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.windowing.triggers.TriggerResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.streaming.util.LatencyStats.Granularity
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
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

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.streamstatus.StatusWatermarkValve.InputChannelStatus
 
watermarkGauge - 类 中的变量org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
WatermarkGauge - org.apache.flink.streaming.runtime.metrics中的类
A Gauge for exposing the current input/output watermark.
WatermarkGauge() - 类 的构造器org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
WatermarkQueueEntry - org.apache.flink.streaming.api.operators.async.queue中的类
StreamElementQueueEntry implementation for the Watermark.
WatermarkQueueEntry(Watermark) - 类 的构造器org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
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 KeyedTriggerWindowDataStream, which evaluates windows over a 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.
windowSerializer - 类 中的变量org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the window in checkpoints.
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).
withBucketAssigner(BucketAssigner<IN, ID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withBucketAssigner(BucketAssigner<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withBucketAssignerAndPolicy(BucketAssigner<IN, ID>, RollingPolicy<IN, ID>) - 类 中的方法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.
withInactivityInterval(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the interval of allowed inactivity after which a part file will have to roll.
WithMasterCheckpointHook<E> - org.apache.flink.streaming.api.checkpoint中的接口
This interface can be implemented by streaming functions that need to trigger a "global action" on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
withMaxPartSize(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the part size above which a part file will have to roll.
withRollingPolicy(RollingPolicy<IN, BucketID>) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withRolloverInterval(long) - 类 中的方法org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the max time a part file can stay open before having to roll.
withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - 类 中的方法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
 
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
Writes a DataStream to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode, String, String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by the path parameter.
writeAsText(String) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by path in text format.
writeAsText(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by path in text format.
WriteFormat<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the BucketingSink 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 BucketingSink 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 BucketingSink for writing to files from a streaming program.
WriteFormatAsText() - 类 的构造器org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
已过时。
 
WriteSinkFunction<IN> - org.apache.flink.streaming.api.functions.sink中的类
已过时。
Please use the BucketingSink 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 BucketingSink 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
Writes the dataStream into an output, described by an OutputFormat.
A B C D E F G H I J K L M N O P Q R S T U V W 
跳过导航链接

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