public class OperatorUtils extends Object
| 构造器和说明 |
|---|
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)
Creates
FeedbackKey from the iterationId and feedbackIndex. |
static org.apache.flink.streaming.api.graph.StreamConfig |
createWrappedOperatorConfig(org.apache.flink.streaming.api.graph.StreamConfig wrapperConfig) |
static org.apache.flink.core.fs.Path |
getDataCachePath(org.apache.flink.configuration.Configuration configuration,
String[] localSpillPaths) |
static String |
getUniqueSenderId(org.apache.flink.runtime.jobgraph.OperatorID operatorId,
int subtaskIndex)
Returns the unique id for the specified operator.
|
static <T> void |
processOperatorOrUdfIfSatisfy(org.apache.flink.streaming.api.operators.StreamOperator<?> operator,
Class<T> targetInterface,
org.apache.flink.util.function.ThrowingConsumer<T,Exception> action) |
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 specified
feedbackConsumer to the feedbackChannel. |
public static String getUniqueSenderId(org.apache.flink.runtime.jobgraph.OperatorID operatorId, int subtaskIndex)
public static <V> org.apache.flink.statefun.flink.core.feedback.FeedbackKey<V> createFeedbackKey(IterationID iterationId, int feedbackIndex)
FeedbackKey from the iterationId and feedbackIndex.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)
feedbackConsumer to the feedbackChannel.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)
public static org.apache.flink.streaming.api.graph.StreamConfig createWrappedOperatorConfig(org.apache.flink.streaming.api.graph.StreamConfig wrapperConfig)
public static org.apache.flink.core.fs.Path getDataCachePath(org.apache.flink.configuration.Configuration configuration,
String[] localSpillPaths)
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)
Copyright © 2019–2022 The Apache Software Foundation. All rights reserved.