
org.apache.flink.streaming.api.datastream.AsyncDataStream Maven / Gradle / Ivy
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.apache.flink.streaming.api.datastream;
import org.apache.flink.annotation.PublicEvolving;
import org.apache.flink.api.common.typeinfo.TypeInformation;
import org.apache.flink.api.java.Utils;
import org.apache.flink.api.java.typeutils.TypeExtractor;
import org.apache.flink.streaming.api.functions.async.AsyncFunction;
import org.apache.flink.streaming.api.functions.async.AsyncRetryStrategy;
import org.apache.flink.streaming.api.operators.async.AsyncWaitOperator;
import org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory;
import org.apache.flink.util.Preconditions;
import java.util.concurrent.TimeUnit;
import static org.apache.flink.streaming.util.retryable.AsyncRetryStrategies.NO_RETRY_STRATEGY;
/**
* A helper class to apply {@link AsyncFunction} to a data stream.
*
* {@code
* DataStream input = ...
* AsyncFunction> asyncFunc = ...
*
* AsyncDataStream.orderedWait(input, asyncFunc, timeout, TimeUnit.MILLISECONDS, 100);
* }
*/
@PublicEvolving
public class AsyncDataStream {
/** Output mode for asynchronous operations. */
public enum OutputMode {
ORDERED,
UNORDERED
}
private static final int DEFAULT_QUEUE_CAPACITY = 100;
/**
* Add an AsyncWaitOperator.
*
* @param in The {@link DataStream} where the {@link AsyncWaitOperator} will be added.
* @param func {@link AsyncFunction} wrapped inside {@link AsyncWaitOperator}.
* @param timeout for the asynchronous operation to complete
* @param bufSize The max number of inputs the {@link AsyncWaitOperator} can hold inside.
* @param mode Processing mode for {@link AsyncWaitOperator}.
* @param asyncRetryStrategy AsyncRetryStrategy for {@link AsyncFunction}.
* @param Input type.
* @param Output type.
* @return A new {@link SingleOutputStreamOperator}
*/
private static SingleOutputStreamOperator addOperator(
DataStream in,
AsyncFunction func,
long timeout,
int bufSize,
OutputMode mode,
AsyncRetryStrategy asyncRetryStrategy) {
if (asyncRetryStrategy != NO_RETRY_STRATEGY) {
Preconditions.checkArgument(
timeout > 0, "Timeout should be configured when do async with retry.");
}
TypeInformation outTypeInfo =
TypeExtractor.getUnaryOperatorReturnType(
func,
AsyncFunction.class,
0,
1,
new int[] {1, 0},
in.getType(),
Utils.getCallLocationName(),
true);
// create transform
AsyncWaitOperatorFactory operatorFactory =
new AsyncWaitOperatorFactory<>(
in.getExecutionEnvironment().clean(func),
timeout,
bufSize,
mode,
asyncRetryStrategy);
return in.transform("async wait operator", outTypeInfo, operatorFactory);
}
/**
* Adds an AsyncWaitOperator. The order of output stream records may be reordered.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout for the asynchronous operation to complete
* @param timeUnit of the given timeout
* @param capacity The max number of async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator unorderedWait(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
int capacity) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
capacity,
OutputMode.UNORDERED,
NO_RETRY_STRATEGY);
}
/**
* Adds an AsyncWaitOperator. The order of output stream records may be reordered.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout for the asynchronous operation to complete
* @param timeUnit of the given timeout
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator unorderedWait(
DataStream in, AsyncFunction func, long timeout, TimeUnit timeUnit) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
DEFAULT_QUEUE_CAPACITY,
OutputMode.UNORDERED,
NO_RETRY_STRATEGY);
}
/**
* Adds an AsyncWaitOperator. The order to process input records is guaranteed to be the same as
* input ones.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout for the asynchronous operation to complete
* @param timeUnit of the given timeout
* @param capacity The max number of async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator orderedWait(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
int capacity) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
capacity,
OutputMode.ORDERED,
NO_RETRY_STRATEGY);
}
/**
* Adds an AsyncWaitOperator. The order to process input records is guaranteed to be the same as
* input ones.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout for the asynchronous operation to complete
* @param timeUnit of the given timeout
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator orderedWait(
DataStream in, AsyncFunction func, long timeout, TimeUnit timeUnit) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
DEFAULT_QUEUE_CAPACITY,
OutputMode.ORDERED,
NO_RETRY_STRATEGY);
}
/**
* Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction. The
* order of output stream records may be reordered.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout from first invoke to final completion of asynchronous operation, may include
* multiple retries, and will be reset in case of restart
* @param timeUnit of the given timeout
* @param asyncRetryStrategy The strategy of reattempt async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator unorderedWaitWithRetry(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy asyncRetryStrategy) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
DEFAULT_QUEUE_CAPACITY,
OutputMode.UNORDERED,
asyncRetryStrategy);
}
/**
* Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction. The
* order of output stream records may be reordered.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout from first invoke to final completion of asynchronous operation, may include
* multiple retries, and will be reset in case of restart
* @param timeUnit of the given timeout
* @param capacity The max number of async i/o operation that can be triggered
* @param asyncRetryStrategy The strategy of reattempt async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator unorderedWaitWithRetry(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy asyncRetryStrategy) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
capacity,
OutputMode.UNORDERED,
asyncRetryStrategy);
}
/**
* Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction. The
* order to process input records is guaranteed to be the same as * input ones.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout from first invoke to final completion of asynchronous operation, may include
* multiple retries, and will be reset in case of restart
* @param timeUnit of the given timeout
* @param asyncRetryStrategy The strategy of reattempt async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator orderedWaitWithRetry(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy asyncRetryStrategy) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
DEFAULT_QUEUE_CAPACITY,
OutputMode.ORDERED,
asyncRetryStrategy);
}
/**
* Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction. The
* order to process input records is guaranteed to be the same as * input ones.
*
* @param in Input {@link DataStream}
* @param func {@link AsyncFunction}
* @param timeout from first invoke to final completion of asynchronous operation, may include
* multiple retries, and will be reset in case of restart
* @param timeUnit of the given timeout
* @param capacity The max number of async i/o operation that can be triggered
* @param asyncRetryStrategy The strategy of reattempt async i/o operation that can be triggered
* @param Type of input record
* @param Type of output record
* @return A new {@link SingleOutputStreamOperator}.
*/
public static SingleOutputStreamOperator orderedWaitWithRetry(
DataStream in,
AsyncFunction func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy asyncRetryStrategy) {
return addOperator(
in,
func,
timeUnit.toMillis(timeout),
capacity,
OutputMode.ORDERED,
asyncRetryStrategy);
}
}
© 2015 - 2025 Weber Informatics LLC | Privacy Policy