Uses of Class
org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Packages that use AsyncDataStream.OutputMode Package Description org.apache.flink.streaming.api.datastream org.apache.flink.streaming.api.operators.async -
-
Uses of AsyncDataStream.OutputMode in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream that return AsyncDataStream.OutputMode Modifier and Type Method Description static AsyncDataStream.OutputMode
AsyncDataStream.OutputMode. valueOf(String name)
Returns the enum constant of this type with the specified name.static AsyncDataStream.OutputMode[]
AsyncDataStream.OutputMode. values()
Returns an array containing the constants of this enum type, in the order they are declared. -
Uses of AsyncDataStream.OutputMode in org.apache.flink.streaming.api.operators.async
Constructors in org.apache.flink.streaming.api.operators.async with parameters of type AsyncDataStream.OutputMode Constructor Description AsyncWaitOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<OUT> parameters, AsyncFunction<IN,OUT> asyncFunction, long timeout, int capacity, AsyncDataStream.OutputMode outputMode, AsyncRetryStrategy<OUT> asyncRetryStrategy, org.apache.flink.streaming.runtime.tasks.ProcessingTimeService processingTimeService, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor)
AsyncWaitOperatorFactory(AsyncFunction<IN,OUT> asyncFunction, long timeout, int capacity, AsyncDataStream.OutputMode outputMode)
AsyncWaitOperatorFactory(AsyncFunction<IN,OUT> asyncFunction, long timeout, int capacity, AsyncDataStream.OutputMode outputMode, AsyncRetryStrategy<OUT> asyncRetryStrategy)
-