@Internal public final class StreamingFunctionUtils extends Object
Functions
. This is similar to FunctionUtils
but has additional methods for invoking interfaces that only exist in the streaming API.Modifier and Type | Method and Description |
---|---|
static void |
restoreFunctionState(org.apache.flink.runtime.state.StateInitializationContext context,
org.apache.flink.api.common.functions.Function userFunction) |
static <T> void |
setOutputType(org.apache.flink.api.common.functions.Function userFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
static void |
snapshotFunctionState(org.apache.flink.runtime.state.StateSnapshotContext context,
org.apache.flink.runtime.state.OperatorStateBackend backend,
org.apache.flink.api.common.functions.Function userFunction) |
public static <T> void setOutputType(org.apache.flink.api.common.functions.Function userFunction, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, org.apache.flink.api.common.ExecutionConfig executionConfig)
public static void snapshotFunctionState(org.apache.flink.runtime.state.StateSnapshotContext context, org.apache.flink.runtime.state.OperatorStateBackend backend, org.apache.flink.api.common.functions.Function userFunction) throws Exception
Exception
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.