Modifier and Type | Method and Description |
---|---|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
Modifier and Type | Class and Description |
---|---|
class |
RichAsyncFunction<IN,OUT>
Rich variant of the
AsyncFunction . |
Constructor and Description |
---|
AsyncWaitOperator(AsyncFunction<IN,OUT> asyncFunction,
long timeout,
int capacity,
AsyncDataStream.OutputMode outputMode,
AsyncRetryStrategy<OUT> asyncRetryStrategy,
ProcessingTimeService processingTimeService,
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) |
Modifier and Type | Method and Description |
---|---|
static GeneratedFunction<AsyncFunction<RowData,RowData>> |
AsyncCodeGenerator.generateFunction(String name,
RowType inputType,
RowType returnType,
List<org.apache.calcite.rex.RexNode> calcProjection,
boolean retainHeader,
ReadableConfig tableConfig,
ClassLoader classLoader)
Creates a generated function which produces an
AsyncFunction which executes the calc
projections. |
Modifier and Type | Class and Description |
---|---|
class |
AsyncFunctionRunner
Async function runner for
AsyncScalarFunction , which
takes the generated function, instantiates it, and then calls its lifecycle methods. |
Constructor and Description |
---|
AsyncFunctionRunner(GeneratedFunction<AsyncFunction<RowData,RowData>> generatedFetcher) |
Modifier and Type | Class and Description |
---|---|
class |
AsyncLookupJoinRunner
The async join runner to lookup the dimension table.
|
class |
AsyncLookupJoinWithCalcRunner
The async join runner with an additional calculate function on the dimension table.
|
Constructor and Description |
---|
AsyncLookupJoinRunner(GeneratedFunction<AsyncFunction<RowData,Object>> generatedFetcher,
DataStructureConverter<RowData,Object> fetcherConverter,
GeneratedResultFuture<TableFunctionResultFuture<RowData>> generatedResultFuture,
GeneratedFunction<FilterCondition> generatedPreFilterCondition,
RowDataSerializer rightRowSerializer,
boolean isLeftOuterJoin,
int asyncBufferCapacity) |
AsyncLookupJoinWithCalcRunner(GeneratedFunction<AsyncFunction<RowData,Object>> generatedFetcher,
DataStructureConverter<RowData,Object> fetcherConverter,
GeneratedFunction<FlatMapFunction<RowData,RowData>> generatedCalc,
GeneratedResultFuture<TableFunctionResultFuture<RowData>> generatedResultFuture,
GeneratedFunction<FilterCondition> generatedPreFilterCondition,
RowDataSerializer rightRowSerializer,
boolean isLeftOuterJoin,
int asyncBufferCapacity) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.