类 OperatorUtils


  • public class OperatorUtils
    extends Object
    Utility class for operators.
    • 方法概要

      所有方法 静态方法 具体方法 
      修饰符和类型 方法 说明
      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, ClassLoader cl)  
      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.
    • 构造器详细资料

      • OperatorUtils

        public OperatorUtils()
    • 方法详细资料

      • 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)
        Creates FeedbackKey from the iterationId and feedbackIndex.
      • 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 specified feedbackConsumer to the feedbackChannel.
      • 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)