IN
- Type of the input elements.@Internal public abstract class AbstractPythonStatelessFunctionRunner<IN> extends AbstractPythonFunctionRunner<IN>
PythonFunctionRunner
used to execute Python stateless functions..baos, baosWrapper, flinkMetricContainer, mainInputReceiver, resultReceiver
Constructor and Description |
---|
AbstractPythonStatelessFunctionRunner(String taskName,
org.apache.beam.sdk.fn.data.FnDataReceiver<byte[]> resultReceiver,
PythonEnvironmentManager environmentManager,
RowType inputType,
RowType outputType,
String functionUrn,
Map<String,String> jobOptions,
FlinkMetricContainer flinkMetricContainer) |
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. |
abstract String |
getInputOutputCoderUrn() |
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.UserDefinedFunction |
getUserDefinedFunctionProto(PythonFunctionInfo pythonFunctionInfo) |
abstract FlinkFnApi.UserDefinedFunctions |
getUserDefinedFunctionsProto()
Gets the proto representation of the Python user-defined functions to be executed.
|
close, createJobBundleFactory, createOutputReceiverFactory, createPythonExecutionEnvironment, finishBundle, open, startBundle
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processElement
public AbstractPythonStatelessFunctionRunner(String taskName, org.apache.beam.sdk.fn.data.FnDataReceiver<byte[]> resultReceiver, PythonEnvironmentManager environmentManager, RowType inputType, RowType outputType, String functionUrn, Map<String,String> jobOptions, FlinkMetricContainer flinkMetricContainer)
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>
Exception
public FlinkFnApi.UserDefinedFunction getUserDefinedFunctionProto(PythonFunctionInfo pythonFunctionInfo)
public RowType getInputType()
public RowType getOutputType()
public abstract String getInputOutputCoderUrn()
@VisibleForTesting public abstract FlinkFnApi.UserDefinedFunctions getUserDefinedFunctionsProto()
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.