IN
- Type of the input elements.OUT
- Type of the execution results.@Internal public abstract class AbstractPythonScalarFunctionRunner<IN,OUT> extends AbstractPythonFunctionRunner<IN,OUT>
PythonFunctionRunner
used to execute Python ScalarFunction
s.LOG
Constructor and Description |
---|
AbstractPythonScalarFunctionRunner(String taskName,
org.apache.beam.sdk.fn.data.FnDataReceiver<OUT> resultReceiver,
PythonFunctionInfo[] scalarFunctions,
PythonEnvironmentManager environmentManager,
RowType inputType,
RowType outputType) |
Modifier and Type | Method and Description |
---|---|
org.apache.beam.runners.core.construction.graph.ExecutableStage |
createExecutableStage()
Creates a
ExecutableStage which contains the Python user-defined functions to be executed
and all the other information needed to execute them, such as the execution environment, the input
and output coder, etc. |
RowType |
getInputType()
Gets the logical type of the input elements of the Python user-defined functions.
|
RowType |
getOutputType()
Gets the logical type of the execution results of the Python user-defined functions.
|
FlinkFnApi.UserDefinedFunctions |
getUserDefinedFunctionsProto()
Gets the proto representation of the Python user-defined functions to be executed.
|
close, createJobBundleFactory, createPythonExecutionEnvironment, finishBundle, getInputTypeSerializer, getOutputTypeSerializer, open, processElement, startBundle
public AbstractPythonScalarFunctionRunner(String taskName, org.apache.beam.sdk.fn.data.FnDataReceiver<OUT> resultReceiver, PythonFunctionInfo[] scalarFunctions, PythonEnvironmentManager environmentManager, RowType inputType, RowType outputType)
public RowType getInputType()
public RowType getOutputType()
public org.apache.beam.runners.core.construction.graph.ExecutableStage createExecutableStage() throws Exception
AbstractPythonFunctionRunner
ExecutableStage
which contains the Python user-defined functions to be executed
and all the other information needed to execute them, such as the execution environment, the input
and output coder, etc.createExecutableStage
in class AbstractPythonFunctionRunner<IN,OUT>
Exception
@VisibleForTesting public FlinkFnApi.UserDefinedFunctions getUserDefinedFunctionsProto()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.