@Internal public abstract class AbstractPythonScalarFunctionFlatMap extends AbstractPythonStatelessFunctionFlatMap
RichFlatMapFunction
used to invoke Python ScalarFunction
functions for the old planner.Modifier and Type | Field and Description |
---|---|
PythonFunctionInfo[] |
scalarFunctions
The Python
ScalarFunction s to be executed. |
bais, baisWrapper, baos, forwardedInputQueue, forwardedInputSerializer, inputType, jobOptions, outputType, pythonFunctionRunner, resultCollector, userDefinedFunctionInputType, userDefinedFunctionOutputType
Constructor and Description |
---|
AbstractPythonScalarFunctionFlatMap(Configuration config,
PythonFunctionInfo[] scalarFunctions,
RowType inputType,
RowType outputType,
int[] udfInputOffsets,
int[] forwardedFields) |
Modifier and Type | Method and Description |
---|---|
void |
bufferInput(Row input) |
int |
getForwardedFieldsCount() |
String |
getFunctionUrn() |
PythonEnv |
getPythonEnv()
Returns the
PythonEnv used to create PythonEnvironmentManager.. |
FlinkFnApi.UserDefinedFunctions |
getUserDefinedFunctionsProto()
Gets the proto representation of the Python user-defined functions to be executed.
|
void |
open(Configuration parameters)
Initialization method for the function.
|
checkInvokeFinishBundleByCount, close, createPythonEnvironmentManager, emitResult, flatMap, getFlinkMetricContainer, getFunctionInput, getInputOutputCoderUrn, getProducedType, getPythonConfig, invokeFinishBundle, processElementInternal
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
public final PythonFunctionInfo[] scalarFunctions
ScalarFunction
s to be executed.public AbstractPythonScalarFunctionFlatMap(Configuration config, PythonFunctionInfo[] scalarFunctions, RowType inputType, RowType outputType, int[] udfInputOffsets, int[] forwardedFields)
public void open(Configuration parameters) throws Exception
RichFunction
The configuration object passed to the function can be used for configuration and initialization. The configuration contains all parameters that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> {
private String searchString;
public void open(Configuration parameters) {
this.searchString = parameters.getString("foo");
}
public boolean filter(String value) {
return value.equals(searchString);
}
}
By default, this method does nothing.
open
in interface RichFunction
open
in class AbstractPythonStatelessFunctionFlatMap
parameters
- The configuration containing the parameters attached to the contract.Exception
- Implementations may forward exceptions, which are caught by the runtime.
When the runtime catches an exception, it aborts the task and lets the fail-over logic
decide whether to retry the task execution.Configuration
public PythonEnv getPythonEnv()
AbstractPythonStatelessFunctionFlatMap
PythonEnv
used to create PythonEnvironmentManager..getPythonEnv
in class AbstractPythonStatelessFunctionFlatMap
public void bufferInput(Row input)
bufferInput
in class AbstractPythonStatelessFunctionFlatMap
public int getForwardedFieldsCount()
getForwardedFieldsCount
in class AbstractPythonStatelessFunctionFlatMap
public FlinkFnApi.UserDefinedFunctions getUserDefinedFunctionsProto()
AbstractPythonStatelessFunctionFlatMap
getUserDefinedFunctionsProto
in class AbstractPythonStatelessFunctionFlatMap
public String getFunctionUrn()
getFunctionUrn
in class AbstractPythonStatelessFunctionFlatMap
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.