Interface PythonFunctionFactory

  • All Known Implementing Classes:
    PythonFunctionFactoryImpl

    public interface PythonFunctionFactory
    The factory which creates the PythonFunction objects from given module name and object name.
    • Method Detail

      • getPythonFunction

        org.apache.flink.table.functions.python.PythonFunction getPythonFunction​(String moduleName,
                                                                                 String objectName)
        Returns PythonFunction according to moduleName and objectName.
        Parameters:
        moduleName - The module name of the Python UDF.
        objectName - The function name / class name of the Python UDF.
        Returns:
        The PythonFunction object which represents the Python UDF.
      • getPythonFunction

        static org.apache.flink.table.functions.python.PythonFunction getPythonFunction​(String fullyQualifiedName,
                                                                                        org.apache.flink.configuration.ReadableConfig config,
                                                                                        ClassLoader classLoader)
                                                                                 throws ExecutionException
        Returns PythonFunction according to the fully qualified name of the Python UDF i.e ${moduleName}.${functionName} or ${moduleName}.${className}.
        Parameters:
        fullyQualifiedName - The fully qualified name of the Python UDF.
        config - The configuration of python dependencies.
        classLoader - The classloader which is used to identify different jobs.
        Returns:
        The PythonFunction object which represents the Python UDF.
        Throws:
        ExecutionException
      • ensureCacheCleanupExecutorServiceStarted

        static void ensureCacheCleanupExecutorServiceStarted()