public class BeamTableStatefulPythonFunctionRunner extends BeamPythonFunctionRunner
BeamTableStatefulPythonFunctionRunner
used to execute Python stateful functions.LOG, mainInputReceiver, resultBuffer, resultTuple
Constructor and Description |
---|
BeamTableStatefulPythonFunctionRunner(String taskName,
PythonEnvironmentManager environmentManager,
RowType inputType,
RowType outputType,
String functionUrn,
FlinkFnApi.UserDefinedAggregateFunctions userDefinedFunctions,
String coderUrn,
Map<String,String> jobOptions,
FlinkMetricContainer flinkMetricContainer,
KeyedStateBackend keyedStateBackend,
TypeSerializer keySerializer,
MemoryManager memoryManager,
double managedMemoryFraction) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.beam.model.pipeline.v1.RunnerApi.Coder |
getInputCoderProto() |
protected org.apache.beam.model.pipeline.v1.RunnerApi.Coder |
getOutputCoderProto() |
protected byte[] |
getUserDefinedFunctionsProtoBytes() |
close, createJobBundleFactory, flush, open, pollResult, process, startBundle
public BeamTableStatefulPythonFunctionRunner(String taskName, PythonEnvironmentManager environmentManager, RowType inputType, RowType outputType, String functionUrn, FlinkFnApi.UserDefinedAggregateFunctions userDefinedFunctions, String coderUrn, Map<String,String> jobOptions, FlinkMetricContainer flinkMetricContainer, KeyedStateBackend keyedStateBackend, TypeSerializer keySerializer, MemoryManager memoryManager, double managedMemoryFraction)
protected byte[] getUserDefinedFunctionsProtoBytes()
getUserDefinedFunctionsProtoBytes
in class BeamPythonFunctionRunner
protected org.apache.beam.model.pipeline.v1.RunnerApi.Coder getInputCoderProto()
getInputCoderProto
in class BeamPythonFunctionRunner
protected org.apache.beam.model.pipeline.v1.RunnerApi.Coder getOutputCoderProto()
getOutputCoderProto
in class BeamPythonFunctionRunner
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.