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