Class PythonConfigUtil


  • public class PythonConfigUtil
    extends Object
    A Util class to handle the configurations of Python jobs.
    • Constructor Detail

      • PythonConfigUtil

        public PythonConfigUtil()
    • Method Detail

      • getEnvironmentConfig

        public static org.apache.flink.configuration.Configuration getEnvironmentConfig​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env)
      • configPythonOperator

        public static void configPythonOperator​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env)
                                         throws Exception
        Throws:
        Exception
      • extractPythonConfiguration

        public static org.apache.flink.configuration.Configuration extractPythonConfiguration​(org.apache.flink.configuration.ReadableConfig config)
        Extract the configurations which is used in the Python operators.
      • getOperatorFactory

        public static org.apache.flink.streaming.api.operators.StreamOperatorFactory<?> getOperatorFactory​(org.apache.flink.api.dag.Transformation<?> transform)
      • isPythonDataStreamOperator

        public static boolean isPythonDataStreamOperator​(org.apache.flink.api.dag.Transformation<?> transform)
      • setPartitionCustomOperatorNumPartitions

        public static void setPartitionCustomOperatorNumPartitions​(List<org.apache.flink.api.dag.Transformation<?>> transformations)
      • convertStateNamesToStateDescriptors

        public static List<org.apache.flink.api.common.state.MapStateDescriptor<ByteArrayWrapper,​byte[]>> convertStateNamesToStateDescriptors​(String[] names)
      • registerPythonBroadcastTransformationTranslator

        public static void registerPythonBroadcastTransformationTranslator()
                                                                    throws Exception
        Throws:
        Exception
      • createSingleOutputStreamOperator

        public static org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator<?> createSingleOutputStreamOperator​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
                                                                                                                               org.apache.flink.api.dag.Transformation<?> transformation)
                                                                                                                        throws Exception
        Throws:
        Exception