A B C D E F G H I J K L M N O P R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Abort a transaction.
- AbstractInput<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
Base abstract implementation of
Input
interface intended to be used when extendingAbstractStreamOperatorV2
. - AbstractInput(AbstractStreamOperatorV2<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractInput
- add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
- addDataset(LineageDataset) - Method in class org.apache.flink.streaming.api.lineage.DefaultSourceLineageVertex
- addLineageDataset(LineageDataset) - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageVertex
- ArrayFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Converts a Tuple to an Object-Array.
- ArrayFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will convert the whole tuple (all fields in the original order) to an array.
- ArrayFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will combine the fields as specified in the indexes parameter in an object array.
- arrayGenerator(DataGenerator<T>, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.Handler that fails the program when timestamp monotony is violated.
- AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.Handler that does nothing when timestamp monotony is violated.
- AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.Handler that only logs violations of timestamp monotony, on WARN log level.
- AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
-
Deprecated.Interface for handlers that handle violations of the monotonous ascending timestamps property.
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
-
A helper class to apply
AsyncFunction
to a data stream. - AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
- AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
-
Output mode for asynchronous operations.
- AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
A function to trigger Async I/O operation.
- asyncInvoke(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
Trigger async operation for each stream input.
- asyncInvoke(IN, ResultFuture<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
- AsyncRetryPredicate<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
Interface encapsulates an asynchronous retry predicate.
- AsyncRetryStrategies - Class in org.apache.flink.streaming.util.retryable
-
Utility class to create concrete
AsyncRetryStrategy
. - AsyncRetryStrategies() - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies
- AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy<OUT> - Class in org.apache.flink.streaming.util.retryable
-
ExponentialBackoffDelayRetryStrategy.
- AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder<OUT> - Class in org.apache.flink.streaming.util.retryable
-
ExponentialBackoffDelayRetryStrategyBuilder for building a ExponentialBackoffDelayRetryStrategy.
- AsyncRetryStrategies.FixedDelayRetryStrategy<OUT> - Class in org.apache.flink.streaming.util.retryable
-
FixedDelayRetryStrategy.
- AsyncRetryStrategies.FixedDelayRetryStrategyBuilder<OUT> - Class in org.apache.flink.streaming.util.retryable
-
FixedDelayRetryStrategyBuilder for building a FixedDelayRetryStrategy.
- AsyncRetryStrategy<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
Interface encapsulates an asynchronous retry strategy.
- AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
The
AsyncWaitOperator
allows to asynchronously process incoming stream records. - AsyncWaitOperator(StreamOperatorParameters<OUT>, AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>, ProcessingTimeService, MailboxExecutor) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- AsyncWaitOperatorFactory<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
The factory of
AsyncWaitOperator
. - AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
- AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, AsyncRetryStrategy<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
B
- beginTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Method that starts a new transaction.
- bigDecimalGenerator(int, int, int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- booleanGenerator() - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- boundedness() - Method in class org.apache.flink.streaming.api.lineage.DefaultSourceLineageVertex
- BoundedOutOfOrdernessTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
-
This is a
WatermarkStrategyWithPeriodicWatermarks
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(Duration) - Constructor for class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
- Bucket<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
A bucket is the directory organization of the output of the
StreamingFileSink
. - bucketCreated(Bucket<IN, BucketID>) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
-
Notifies a new bucket has been created.
- BucketFactory<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
-
A factory able to create
buckets
for theStreamingFileSink
. - bucketInactive(Bucket<IN, BucketID>) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
-
Notifies a bucket become inactive.
- BucketLifeCycleListener<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
-
Listener about the status of
Bucket
. - Buckets<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
The manager of the different active buckets in the
StreamingFileSink
. - Buckets(Path, BucketAssigner<IN, BucketID>, BucketFactory<IN, BucketID>, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, int, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
A constructor creating a new empty bucket manager.
- BucketsBuilder() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BucketsBuilder
-
Deprecated.
- build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.Creates the actual sink.
- build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.Creates the actual sink.
- build() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
- build() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
- BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>, CheckpointRollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- byteGenerator(byte, byte) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- byteGenerator(byte, byte) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
C
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- canRetry(int) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
- canRetry(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
- canRetry(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
- checkCollection(Collection<X>, Class<X>) - Static method in class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- CheckpointCommitter - Class in org.apache.flink.streaming.runtime.operators
-
This class is used to save information about which sink operator instance has committed checkpoints to a backend.
- CheckpointCommitter() - Constructor for class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- close() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.experimental.CollectSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
- close() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Closes the resource/connection to it.
- close() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- closePartFileForBucket(BucketID) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- CollectionInputFormat<T> - Class in org.apache.flink.streaming.api.legacy.io
-
An input format that returns objects from a collection.
- CollectionInputFormat(Collection<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- CollectSink<IN> - Class in org.apache.flink.streaming.experimental
-
A specialized data sink to be used by DataStreamUtils.collect().
- CollectSink(InetAddress, int, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.experimental.CollectSink
-
Creates a CollectSink that will send the data to the specified host.
- commit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Commit a pre-committed transaction.
- commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Mark the given checkpoint as completed in the resource.
- commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- complete(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future with a collection of result objects.
- completeExceptionally(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future exceptionally with an exception.
- ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Combines two extractors which will be executed one after each other.
- ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
Combines two extractors which will be executed one after each other.
- config() - Method in interface org.apache.flink.streaming.api.lineage.DatasetConfigFacet
- configure(Configuration) - Method in class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- context - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- ContinuousEventTimeTrigger<W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval. - ContinuousProcessingTimeTrigger<W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval as measured by the clock of the machine on which the job is running. - copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the cosine distance between two given vectors.
- CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
- CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
-
The factory method; creates the value.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BucketsBuilder
-
Deprecated.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BucketsBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- createBucketWriter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- createExceptionTypePredicate(Class<? extends Throwable>) - Static method in class org.apache.flink.streaming.util.retryable.RetryPredicates
-
Creates a predicate on given exception type.
- createInstance() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- createResource() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Creates/opens/connects to the resource that is used to store information.
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
- createWriter(WriterInitContext) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSink
- createWriter(WriterInitContext) - Method in class org.apache.flink.streaming.api.functions.sink.v2.DiscardingSink
- currentTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
D
- DataGenerator<T> - Interface in org.apache.flink.streaming.api.functions.source.datagen
-
Stateful and re-scalable data generator.
- DataGeneratorSource<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
-
Deprecated.Use
org.apache.flink.connector.datagen.source.DataGeneratorSource
instead. - DataGeneratorSource(DataGenerator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.Creates a source that emits records by
DataGenerator
without controlling emit rate. - DataGeneratorSource(DataGenerator<T>, long, Long) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.Creates a source that emits records by
DataGenerator
. - DatasetConfigFacet - Interface in org.apache.flink.streaming.api.lineage
-
Builtin config facet for dataset.
- datasets() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageVertex
- datasets() - Method in class org.apache.flink.streaming.api.lineage.DefaultSourceLineageVertex
- DatasetSchemaFacet - Interface in org.apache.flink.streaming.api.lineage
-
Builtin schema facet for dataset.
- DatasetSchemaField<T> - Interface in org.apache.flink.streaming.api.lineage
-
Field for schema in dataset.
- DataStreamUtils - Class in org.apache.flink.streaming.api.datastream
-
A collection of utilities for
DataStreams
. - DEFAULT_BUCKET_CHECK_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BucketsBuilder
-
Deprecated.
- DefaultBucketFactoryImpl<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
A factory returning
buckets
. - DefaultBucketFactoryImpl() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
- DefaultJobCreatedEvent - Class in org.apache.flink.streaming.runtime.execution
-
Default implementation for
JobCreatedEvent
. - DefaultJobCreatedEvent(JobID, String, LineageGraph, RuntimeExecutionMode) - Constructor for class org.apache.flink.streaming.runtime.execution.DefaultJobCreatedEvent
- DefaultLineageVertex - Class in org.apache.flink.streaming.api.lineage
-
Default implementation for
LineageVertex
. - DefaultLineageVertex() - Constructor for class org.apache.flink.streaming.api.lineage.DefaultLineageVertex
- DefaultSourceLineageVertex - Class in org.apache.flink.streaming.api.lineage
-
Default implementation for
SourceLineageVertex
. - DefaultSourceLineageVertex(Boundedness) - Constructor for class org.apache.flink.streaming.api.lineage.DefaultSourceLineageVertex
- DeltaEvictor<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps elements based on aDeltaFunction
and a threshold. - DeltaFunction<DATA> - Interface in org.apache.flink.streaming.api.functions.windowing.delta
-
This interface allows the implementation of a function which calculates the delta between two data points.
- DeltaTrigger<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires based on aDeltaFunction
and a threshold. - deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- deserialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataInputView) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- DiscardingSink<T> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
DiscardingSink
interface instead. - DiscardingSink<IN> - Class in org.apache.flink.streaming.api.functions.sink.v2
-
A special sink that ignores all elements.
- DiscardingSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.DiscardingSink
-
Deprecated.
- DiscardingSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.v2.DiscardingSink
- doubleGenerator(double, double) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- doubleGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- duplicate() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- DynamicEventTimeSessionWindows<T> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the timestamp of the elements. - DynamicEventTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- DynamicProcessingTimeSessionWindows<T> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the current processing time. - DynamicProcessingTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
E
- elapsedTime(Clock) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.TransactionHolder
-
Deprecated.
- emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- emitCompletedElement(TimestampedCollector<OUT>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Emits one completed element from the head of this queue into the given output.
- emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- EMPTY_RESULT_PREDICATE - Static variable in class org.apache.flink.streaming.util.retryable.RetryPredicates
-
A predicate matches empty result which means an empty
Collection
. - enableTransactionTimeoutWarnings(double) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Enables logging of warnings if a transaction's elapsed time reaches a specified ratio of the
transactionTimeout
. - endInput() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- environment - Variable in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.TransactionHolder
-
Deprecated.
- EuclideanDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the euclidean distance between two given points.
- EuclideanDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
- EuclideanDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
- EventTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the timestamp of the elements. - EventTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
- evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
- evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
- evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
- exceptionPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryPredicate
-
An Optional Java that defines a condition on asyncFunction's exception which will trigger a later reattempt operation, will be called before user's ResultFuture#completeExceptionally.
- executionMode() - Method in class org.apache.flink.streaming.runtime.execution.DefaultJobCreatedEvent
- executionMode() - Method in interface org.apache.flink.streaming.runtime.execution.JobCreatedEvent
- ExponentialBackoffDelayRetryStrategy(int, long, long, double, Predicate<Collection<OUT>>, Predicate<Throwable>) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
- ExponentialBackoffDelayRetryStrategyBuilder(int, long, long, double) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
- extract(FROM) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
- extract(FROM) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.extractor.Extractor
-
Extracts/Converts the given input to an object of the output type.
- extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
- extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
- extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
- extract(T) - Method in interface org.apache.flink.streaming.api.windowing.assigners.SessionWindowTimeGapExtractor
-
Extracts the session time gap.
- extractAscendingTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.Extracts the timestamp from the given element.
- ExtractionAwareDeltaFunction<DATA,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
Extend this abstract class to implement a delta function which is aware of extracting the data on which the delta is calculated from a more complex data structure.
- ExtractionAwareDeltaFunction(Extractor<DATA, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
- Extractor<FROM,TO> - Interface in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extractors allow to extract/convert one type to another.
- extractTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
Extracts the timestamp from the given element.
- extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
F
- FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
-
Deprecated.
- FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of an array.
- FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the first field (id 0) from the array.
- FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the field with the given id from the array.
- FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of a tuple.
- FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the field with the given id from the tuple.
- fields() - Method in interface org.apache.flink.streaming.api.lineage.DatasetSchemaFacet
- FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts multiple fields from an array and puts them into a new array of the specified type.
- FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
Extracts multiple fields from an array and puts them in the given order into a new array of the specified type.
- FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
- FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
Extracts one or more fields of the type Double from a tuple and puts them into a new double[] (in the specified order).
- FileLifeCycleListener<BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
-
Listener about the status of file.
- finish() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- finishProcessing(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.This method is called at the end of data processing.
- finishRecoveringContext(Collection<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Callback for subclasses which is called after restoring (each) user context.
- FixedDelayRetryStrategyBuilder(int, long) - Constructor for class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
- FlinkChillPackageRegistrar - Class in org.apache.flink.streaming.util.serialize
-
Registers all chill serializers used for Java types.
- FlinkChillPackageRegistrar() - Constructor for class org.apache.flink.streaming.util.serialize.FlinkChillPackageRegistrar
- floatGenerator(float, float) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- floatGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- forBulkFormat(Path, BulkWriter.Factory<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.Creates the builder for a
StreamingFileSink
with bulk-encoding format. - format(IN) - Method in interface org.apache.flink.streaming.api.legacy.io.TextOutputFormat.TextFormatter
-
Deprecated.
- forRowFormat(Path, Encoder<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.Creates the builder for a
StreamingFileSink
with row-encoding format. - forTimestamp(long) - Static method in class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
-
Creates a
SinkFunction.Context
that throws an exception when trying to access the current watermark or processing time.
G
- GenericWriteAheadSink<IN> - Class in org.apache.flink.streaming.runtime.operators
-
Generic Sink that emits its input elements into an arbitrary backend.
- GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Looks up the value mapped under the given key.
- getBackoffTimeMillis(int) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
- getBackoffTimeMillis(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
- getBackoffTimeMillis(int) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
- getBindAddress() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
- getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- getBucketId() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
- getBucketPath() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
- getCharsetName() - Method in class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- getCharsetName() - Method in class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
- getContext() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- getCurrentTableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the current table capacity, i.e., the number of slots in the hash table, without and overflow chaining.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- getDelta(DATA, DATA) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
-
Calculates the delta between two given data points.
- getDelta(DATA, DATA) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
This method takes the two data point and runs the set extractor on it.
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- getKey() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
- getLength() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the base-2 logarithm of the hash table capacity, as returned by
KeyMap.getCurrentTableCapacity()
. - getMaxOutOfOrdernessInMillis() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
- getMaxPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
- getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
This method is exactly the same as
DeltaFunction.getDelta(Object, Object)
except that it gets the result of the previously done extractions as input. - getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
- getNewBucket(int, BucketID, Path, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
- getNextRegistrationId() - Method in class org.apache.flink.streaming.util.serialize.FlinkChillPackageRegistrar
- getPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
- getPendingCommitTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- getPendingTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- getPort() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Returns the port on which the iterator is getting the data.
- getRecordProcessor(int) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- getRehashThreshold() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
- getRetryPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy
- getRetryPredicate() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy
- getRetryPredicate() - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategy
- getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
- getUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
H
- handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
-
Deprecated.
- handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
-
Deprecated.
- handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
-
Deprecated.
- handleViolation(long, long) - Method in interface org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.MonotonyViolationHandler
-
Deprecated.Called when the property of monotonously ascending timestamps is violated, i.e., when
elementTimestamp < lastTimestamp
. - HAS_EXCEPTION_PREDICATE - Static variable in class org.apache.flink.streaming.util.retryable.RetryPredicates
-
A predicate matches any exception which means a non-null
Throwable
. - hasCompletedElements() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- hasCompletedElements() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Checks if there is at least one completed head element.
- hasCompletedElements() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.TransactionHolder
-
Deprecated.
- hasKeyContext() - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- hasNext() - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- hasNext() - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- hasNext() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Returns true if the DataStream has more elements.
I
- ifException(Predicate<Throwable>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
- ifException(Predicate<Throwable>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
- ifResult(Predicate<Collection<OUT>>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder
- ifResult(Predicate<Collection<OUT>>) - Method in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.FixedDelayRetryStrategyBuilder
- ignoreFailuresAfterTransactionTimeout() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.If called, the sink will only log but not propagate exceptions thrown in
TwoPhaseCommitSinkFunction.recoverAndCommit(Object)
if the transaction is older than a specified transaction timeout. - IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
-
Deprecated.
- InetSocketAddressSerializer - Class in org.apache.flink.streaming.util.serialize
-
InetSocketAddressSerializer is a Kryo 5.x serializer for InetSocketAddress.
- InetSocketAddressSerializer() - Constructor for class org.apache.flink.streaming.util.serialize.InetSocketAddressSerializer
- initializeState(ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
Initializes the state after recovery from a failure.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- initializeUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- inputId - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
- intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.This should not be implemented by subclasses.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.experimental.CollectSink
- invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.DiscardingSink
-
Deprecated.
- invoke(TXN, IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Write value within a transaction.
- isAsyncStateProcessingEnabled() - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Checked the resource whether the given checkpoint was committed completely.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- isEmpty() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
True if the queue is empty; otherwise false.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Checks whether the map is empty.
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- isImmutableType() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates an iterator over the entries of this map.
J
- JobCreatedEvent - Interface in org.apache.flink.streaming.runtime.execution
-
Basic job created event.
- jobId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
- jobId() - Method in class org.apache.flink.streaming.runtime.execution.DefaultJobCreatedEvent
- jobName() - Method in class org.apache.flink.streaming.runtime.execution.DefaultJobCreatedEvent
K
- keyDone() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called when the traversal for the current key is complete.
- KeyMap<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
- KeyMap() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates a new hash table with the default initial capacity.
- KeyMap(int) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates a new table with a capacity tailored to the given expected number of elements.
- KeyMap.Entry<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
An entry in the hash table.
- KeyMap.LazyFactory<V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
-
A factory for lazy/on-demand instantiation of values.
- KeyMap.TraversalEvaluator<K,V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
-
A visitor for a traversal over the union of multiple hash maps.
L
- lineageGraph() - Method in class org.apache.flink.streaming.runtime.execution.DefaultJobCreatedEvent
- lineageGraph() - Method in interface org.apache.flink.streaming.runtime.execution.JobCreatedEvent
- LOG - Static variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
- LOG - Static variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
-
Deprecated.
- longGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- longGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
M
- mapGenerator(DataGenerator<K>, DataGenerator<V>, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
Merge overlapping
TimeWindow
s. - mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
Merge overlapping
TimeWindow
s. - mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Merge overlapping
TimeWindow
s. - mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Merge overlapping
TimeWindow
s. - MultipleConnectedStreams - Class in org.apache.flink.streaming.api.datastream
-
This is a very basic and rough stub for a class connecting multiple input
DataStream
s into one, usingMultipleInputStreamOperator
. - MultipleConnectedStreams(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
N
- name() - Method in interface org.apache.flink.streaming.api.lineage.DatasetSchemaField
-
The name of the field.
- next() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Returns the next element of the DataStream.
- nextRecord(T) - Method in class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- nextValue(V) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called for each value found for the current key.
- nextWithNullRate(Supplier<T>) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- NO_RETRY_STRATEGY - Static variable in class org.apache.flink.streaming.util.retryable.AsyncRetryStrategies
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- notifyOfError(Throwable) - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
- nullRate - Variable in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
O
- of(double, DeltaFunction<T>) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a
DeltaEvictor
from the given threshold andDeltaFunction
. - of(double, DeltaFunction<T>, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a
DeltaEvictor
from the given threshold,DeltaFunction
. - of(double, DeltaFunction<T>, TypeSerializer<T>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
Creates a delta trigger from the given threshold and
DeltaFunction
. - of(Duration) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a
TimeEvictor
that keeps the given number of elements. - of(Duration) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(Duration) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(Duration, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a
TimeEvictor
that keeps the given number of elements. - of(Trigger<T, W>, Duration) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
Creates a new
ProcessingTimeoutTrigger
that fires when the inner trigger is fired or when the timeout timer fires. - of(Trigger<T, W>, Duration, boolean, boolean) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
-
Creates a new
ProcessingTimeoutTrigger
that fires when the inner trigger is fired or when the timeout timer fires. - onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- onElement(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- onPartFileOpened(BucketID, Path) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.FileLifeCycleListener
-
Notifies a new file has been opened.
- onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
- onWatermark(KEY, Watermark) - Method in interface org.apache.flink.streaming.api.operators.OnWatermarkCallback
-
The action to be triggered upon reception of a watermark.
- OnWatermarkCallback<KEY> - Interface in org.apache.flink.streaming.api.operators
-
A callback registered with the
InternalWatermarkCallbackService
service. - open() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- open() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Opens/connects to the resource, and possibly creates it beforehand.
- open() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- open(String, FunctionInitializationContext, RuntimeContext) - Method in interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
-
Open and initialize state for
DataGenerator
. - open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.experimental.CollectSink
-
Initialize the connection with the Socket in the server.
- open(GenericInputSplit) - Method in class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- operatorId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
- ORDERED - org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
- OrderedStreamElementQueue<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
-
Ordered
StreamElementQueue
implementation. - OrderedStreamElementQueue(int) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- orderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- orderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- org.apache.flink.streaming.api.datastream - package org.apache.flink.streaming.api.datastream
- org.apache.flink.streaming.api.functions.async - package org.apache.flink.streaming.api.functions.async
- org.apache.flink.streaming.api.functions.co - package org.apache.flink.streaming.api.functions.co
- org.apache.flink.streaming.api.functions.sink - package org.apache.flink.streaming.api.functions.sink
- org.apache.flink.streaming.api.functions.sink.filesystem - package org.apache.flink.streaming.api.functions.sink.filesystem
- org.apache.flink.streaming.api.functions.sink.filesystem.legacy - package org.apache.flink.streaming.api.functions.sink.filesystem.legacy
- org.apache.flink.streaming.api.functions.sink.legacy - package org.apache.flink.streaming.api.functions.sink.legacy
- org.apache.flink.streaming.api.functions.sink.v2 - package org.apache.flink.streaming.api.functions.sink.v2
- org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
- org.apache.flink.streaming.api.functions.source.datagen - package org.apache.flink.streaming.api.functions.source.datagen
- org.apache.flink.streaming.api.functions.timestamps - package org.apache.flink.streaming.api.functions.timestamps
- org.apache.flink.streaming.api.functions.windowing - package org.apache.flink.streaming.api.functions.windowing
- org.apache.flink.streaming.api.functions.windowing.delta - package org.apache.flink.streaming.api.functions.windowing.delta
- org.apache.flink.streaming.api.functions.windowing.delta.extractor - package org.apache.flink.streaming.api.functions.windowing.delta.extractor
- org.apache.flink.streaming.api.legacy.io - package org.apache.flink.streaming.api.legacy.io
- org.apache.flink.streaming.api.lineage - package org.apache.flink.streaming.api.lineage
- org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
- org.apache.flink.streaming.api.operators.async - package org.apache.flink.streaming.api.operators.async
- org.apache.flink.streaming.api.operators.async.queue - package org.apache.flink.streaming.api.operators.async.queue
- org.apache.flink.streaming.api.windowing.assigners - package org.apache.flink.streaming.api.windowing.assigners
- org.apache.flink.streaming.api.windowing.evictors - package org.apache.flink.streaming.api.windowing.evictors
- org.apache.flink.streaming.api.windowing.triggers - package org.apache.flink.streaming.api.windowing.triggers
- org.apache.flink.streaming.experimental - package org.apache.flink.streaming.experimental
-
This package holds classes that are experimental.
- org.apache.flink.streaming.runtime.execution - package org.apache.flink.streaming.runtime.execution
- org.apache.flink.streaming.runtime.operators - package org.apache.flink.streaming.runtime.operators
-
This package contains the operators that perform the stream transformations.
- org.apache.flink.streaming.runtime.operators.windowing - package org.apache.flink.streaming.runtime.operators.windowing
-
This package contains the operators that implement the various window operations on data streams.
- org.apache.flink.streaming.runtime.tasks - package org.apache.flink.streaming.runtime.tasks
-
This package contains classes that realize streaming tasks.
- org.apache.flink.streaming.util.retryable - package org.apache.flink.streaming.util.retryable
- org.apache.flink.streaming.util.serialize - package org.apache.flink.streaming.util.serialize
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
- owner - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
P
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- pendingTransaction - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- pendingTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- preCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Pre commit previously created transaction.
- PrintSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Sink implementation writing every element to the standard output or standard error stream.
- PrintSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink function that prints to STDOUT.
- PrintSink(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT or STDERR.
- PrintSink(String) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT and gives a sink identifier.
- PrintSink(String, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSink
-
Instantiates a print sink that prints to STDOUT or STDERR and gives a sink identifier.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- ProcessingTimeoutTrigger<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that can turn anyTrigger
into a timeoutTrigger
. - ProcessingTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the current processing time. - ProcessingTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- processRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts the given value, mapped under the given key.
- putIfAbsent(K, KeyMap.LazyFactory<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts a value for the given key, if no value is yet contained for that key.
- putOrAggregate(K, V, ReduceFunction<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts or aggregates a value into the hash map.
R
- random - Variable in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- RandomGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
-
Random generator.
- RandomGenerator() - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- reachedEnd() - Method in class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- read(Kryo, Input, Class<? extends InetSocketAddress>) - Method in class org.apache.flink.streaming.util.serialize.InetSocketAddressSerializer
- readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- readRecord(String, byte[], int, int) - Method in class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- recoverAndAbort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Abort a transaction that was rejected by a coordinator after a failure.
- recoverAndCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Invoked on recovered transactions after a failure.
- registerSerializers(Kryo) - Method in class org.apache.flink.streaming.util.serialize.FlinkChillPackageRegistrar
- reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
Reinterprets the given
DataStream
as aKeyedStream
, which extracts keys with the givenKeySelector
. - reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
Reinterprets the given
DataStream
as aKeyedStream
, which extracts keys with the givenKeySelector
. - remove() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketFactory
- restoreBucket(int, long, BucketWriter<IN, BucketID>, RollingPolicy<IN, BucketID>, BucketState<BucketID>, FileLifeCycleListener<BucketID>, OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.DefaultBucketFactoryImpl
- ResultFuture<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
ResultFuture
collects data / error in user codes while processing async i/o. - resultPredicate() - Method in interface org.apache.flink.streaming.api.functions.async.AsyncRetryPredicate
-
An Optional Java that defines a condition on asyncFunction's future result which will trigger a later reattempt operation, will be called before user's ResultFuture#complete.
- RetryPredicates - Class in org.apache.flink.streaming.util.retryable
-
Utility class to create concrete retry predicates.
- RetryPredicates() - Constructor for class org.apache.flink.streaming.util.retryable.RetryPredicates
- RichAllWindowFunction<IN,OUT,W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
A
RichFunction
version ofAllWindowFunction
. - RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
- RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
-
Rich variant of the
AsyncFunction
. - RichAsyncFunction() - Constructor for class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
- RichCoFlatMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
- RichCoFlatMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
- RichCoMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoMapFunction represents a Map transformation with two different input types.
- RichCoMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoMapFunction
- RichWindowFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Rich variant of the
WindowFunction
. - RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
- RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>, RollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
S
- self() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BucketsBuilder
-
Deprecated.
- sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
Write the given element into the backend.
- SequenceGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
-
A stateful, re-scalable
DataGenerator
that emits each number from a given interval exactly once, possibly in parallel. - SequenceGenerator(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
-
Creates a DataGenerator that emits all numbers from the given interval exactly once.
- serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- serializer - Variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- SessionWindowTimeGapExtractor<T> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
A
SessionWindowTimeGapExtractor
extracts session time gaps for Dynamic Session Window Assigners. - setBucketLifeCycleListener(BucketLifeCycleListener<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- setCharsetName(String) - Method in class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- setCharsetName(String) - Method in class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
- setContext(Optional<CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- setFileLifeCycleListener(FileLifeCycleListener<BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- setJobId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the job ID after instantiation.
- setKeyContextElement(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
- setOperatorId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the operator ID after instantiation.
- setPendingCommitTransactions(List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- setPendingTransaction(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
- setTransactionTimeout(long) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Sets the transaction timeout.
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- SinkContextUtil - Class in org.apache.flink.streaming.api.functions.sink
-
Utility for creating Sink
Contexts
. - SinkContextUtil() - Constructor for class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- size() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Return the size of the queue.
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the number of elements currently in the map.
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- snapshotState(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- snapshotState(long, ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
-
Snapshot state for
DataGenerator
. - snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
- SocketStreamIterator<T> - Class in org.apache.flink.streaming.experimental
-
An iterator that returns the data from a socket stream.
- SocketStreamIterator(int, InetAddress, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with custom port and bind address.
- SocketStreamIterator(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with automatic port and bind address.
- startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called whenever the traversal starts with a new key.
- state - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
- State() - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- State(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>, List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>, Optional<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.State
-
Deprecated.
- stateKeySelector - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
-
KeySelector
for extracting a key from an element being processed. - StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializer
-
Deprecated.
- StateSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- StreamElementQueue<OUT> - Interface in org.apache.flink.streaming.api.operators.async.queue
-
Interface for stream element queues for the
AsyncWaitOperator
. - StreamingFileSink<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.Use
org.apache.flink.connector.file.sink.FileSink
instead. - StreamingFileSink(StreamingFileSink.BucketsBuilder<IN, ?, ? extends StreamingFileSink.BucketsBuilder<IN, ?, ?>>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink
-
Deprecated.Creates a new
StreamingFileSink
that writes files to the given base directory with the give buckets properties. - StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.The base abstract class for the
StreamingFileSink.RowFormatBuilder
andStreamingFileSink.BulkFormatBuilder
. - StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.A builder for configuring the sink for bulk-encoding formats, e.g.
- StreamingFileSink.DefaultBulkFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.Builder for the vanilla
StreamingFileSink
using a bulk format. - StreamingFileSink.DefaultRowFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.Builder for the vanilla
StreamingFileSink
using a row format. - StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
-
Deprecated.A builder for configuring the sink for row-wise encoding formats.
- StreamingFileSinkHelper<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
-
Helper for
StreamingFileSink
. - StreamingFileSinkHelper(Buckets<IN, ?>, boolean, OperatorStateStore, ProcessingTimeService, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
- stringGenerator(int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- stringGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
T
- TextInputFormat - Class in org.apache.flink.streaming.api.legacy.io
-
Deprecated.If you want to read/write data from/to text file, please use FLIP-27 FileSource and Sink-V2 FlinkSink. This class should be removed if we drop the supports for read/write via input/output format in DataStream api.
- TextInputFormat(Path) - Constructor for class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- TextOutputFormat<T> - Class in org.apache.flink.streaming.api.legacy.io
-
Deprecated.If you want to read/write data from/to text file, please use FLIP-27 FileSource and Sink-V2 FlinkSink. This class should be removed if we drop all supports for
InputFormat
andOutputFormat
- TextOutputFormat(Path) - Constructor for class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
- TextOutputFormat(Path, String) - Constructor for class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
- TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.streaming.api.legacy.io
-
Deprecated.Formatter that transforms values into their
String
representations. - TimeEvictor<W extends org.apache.flink.streaming.api.windowing.windows.Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps elements for a certain amount of time. - TimeEvictor(long) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
- TimeEvictor(long, boolean) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
- timeout(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.TransactionHolder
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSink
- toString() - Method in class org.apache.flink.streaming.api.legacy.io.CollectionInputFormat
- toString() - Method in class org.apache.flink.streaming.api.legacy.io.TextInputFormat
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeoutTrigger
- TransactionHolder(TXN, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.TransactionHolder
-
Deprecated.
- transform(AbstractMultipleInputTransformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
- traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Performs a traversal about logical the multi-map that results from the union of the given maps.
- tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- tryPut(StreamElement) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Tries to put the given element in the queue.
- tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
Sink
interface instead. - TwoPhaseCommitSinkFunction(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.Use default
ListStateDescriptor
for internal state serialization. - TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
- TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.Custom
TypeSerializer
for the sink state. - TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.Snapshot for the
TwoPhaseCommitSinkFunction.StateSerializer
. - TwoPhaseCommitSinkFunction.TransactionHolder<TXN> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.Adds metadata (currently only the start time of the transaction) to the transaction object.
- type() - Method in interface org.apache.flink.streaming.api.lineage.DatasetSchemaField
-
The type of the field.
U
- UNORDERED - org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
- UnorderedStreamElementQueue<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
-
Unordered implementation of the
StreamElementQueue
. - UnorderedStreamElementQueue(int) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator.
- unorderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- unorderedWaitWithRetry(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, AsyncRetryStrategy<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
- userContext - Variable in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction
-
Deprecated.
V
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
- values() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Returns the collection of
StreamElement
currently contained in this queue for checkpointing. - values() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
- valuesToEmit - Variable in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
- varLen - Variable in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
W
- withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withBucketFactory(BucketFactory<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withBucketFactory(BucketFactory<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withGap(Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withGap(Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns elements to sessions based on the element timestamp. - withNewBucketAssigner(BucketAssigner<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withNewBucketAssignerAndPolicy(BucketAssigner<IN, ID>, RollingPolicy<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withNullRate(float) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withRollingPolicy(CheckpointRollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.BulkFormatBuilder
-
Deprecated.
- withRollingPolicy(RollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink.RowFormatBuilder
-
Deprecated.
- withVarLen(boolean) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
- withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Deprecated.Sets the handler for violations to the ascending timestamp order.
- write(Kryo, Output, InetSocketAddress) - Method in class org.apache.flink.streaming.util.serialize.InetSocketAddressSerializer
- writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
-
Deprecated.
- writeRecord(T) - Method in class org.apache.flink.streaming.api.legacy.io.TextOutputFormat
-
Deprecated.
All Classes All Packages