类 OperatorUtils
- java.lang.Object
-
- org.apache.flink.iteration.operator.OperatorUtils
-
public class OperatorUtils extends Object
Utility class for operators.
-
-
构造器概要
构造器 构造器 说明 OperatorUtils()
-
方法概要
所有方法 静态方法 具体方法 修饰符和类型 方法 说明 static org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException>createDataCacheFileGenerator(org.apache.flink.core.fs.Path basePath, String fileTypeName, org.apache.flink.runtime.jobgraph.OperatorID operatorId)static <V> org.apache.flink.statefun.flink.core.feedback.FeedbackKey<V>createFeedbackKey(IterationID iterationId, int feedbackIndex)CreatesFeedbackKeyfrom theiterationIdandfeedbackIndex.static org.apache.flink.streaming.api.graph.StreamConfigcreateWrappedOperatorConfig(org.apache.flink.streaming.api.graph.StreamConfig wrapperConfig, ClassLoader cl)static org.apache.flink.core.fs.PathgetDataCachePath(org.apache.flink.configuration.Configuration configuration, String[] localSpillPaths)static StringgetUniqueSenderId(org.apache.flink.runtime.jobgraph.OperatorID operatorId, int subtaskIndex)Returns the unique id for the specified operator.static <T> voidprocessOperatorOrUdfIfSatisfy(org.apache.flink.streaming.api.operators.StreamOperator<?> operator, Class<T> targetInterface, org.apache.flink.util.function.ThrowingConsumer<T,Exception> action)static <V> voidregisterFeedbackConsumer(org.apache.flink.statefun.flink.core.feedback.FeedbackChannel<V> feedbackChannel, org.apache.flink.statefun.flink.core.feedback.FeedbackConsumer<V> feedbackConsumer, Executor executor)Registers the specifiedfeedbackConsumerto thefeedbackChannel.
-
-
-
方法详细资料
-
getUniqueSenderId
public static String getUniqueSenderId(org.apache.flink.runtime.jobgraph.OperatorID operatorId, int subtaskIndex)
Returns the unique id for the specified operator.
-
createFeedbackKey
public static <V> org.apache.flink.statefun.flink.core.feedback.FeedbackKey<V> createFeedbackKey(IterationID iterationId, int feedbackIndex)
CreatesFeedbackKeyfrom theiterationIdandfeedbackIndex.
-
registerFeedbackConsumer
public static <V> void registerFeedbackConsumer(org.apache.flink.statefun.flink.core.feedback.FeedbackChannel<V> feedbackChannel, org.apache.flink.statefun.flink.core.feedback.FeedbackConsumer<V> feedbackConsumer, Executor executor)Registers the specifiedfeedbackConsumerto thefeedbackChannel.
-
processOperatorOrUdfIfSatisfy
public static <T> void processOperatorOrUdfIfSatisfy(org.apache.flink.streaming.api.operators.StreamOperator<?> operator, Class<T> targetInterface, org.apache.flink.util.function.ThrowingConsumer<T,Exception> action)
-
createWrappedOperatorConfig
public static org.apache.flink.streaming.api.graph.StreamConfig createWrappedOperatorConfig(org.apache.flink.streaming.api.graph.StreamConfig wrapperConfig, ClassLoader cl)
-
getDataCachePath
public static org.apache.flink.core.fs.Path getDataCachePath(org.apache.flink.configuration.Configuration configuration, String[] localSpillPaths)
-
createDataCacheFileGenerator
public static org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException> createDataCacheFileGenerator(org.apache.flink.core.fs.Path basePath, String fileTypeName, org.apache.flink.runtime.jobgraph.OperatorID operatorId)
-
-