@Internal public class BeamDataStreamPythonFunctionRunner extends BeamPythonFunctionRunner
BeamDataStreamPythonFunctionRunner
is responsible for starting a beam python harness to
execute user defined python function.inputCoderDescriptor, LOG, mainInputReceiver, outputCoderDescriptor, resultBuffer, sideOutputCoderDescriptors
Constructor and Description |
---|
BeamDataStreamPythonFunctionRunner(String taskName,
ProcessPythonEnvironmentManager environmentManager,
String headOperatorFunctionUrn,
List<FlinkFnApi.UserDefinedDataStreamFunction> userDefinedDataStreamFunctions,
FlinkMetricContainer flinkMetricContainer,
KeyedStateBackend<?> keyedStateBackend,
OperatorStateBackend operatorStateBackend,
TypeSerializer<?> keySerializer,
TypeSerializer<?> namespaceSerializer,
TimerRegistration timerRegistration,
MemoryManager memoryManager,
double managedMemoryFraction,
FlinkFnApi.CoderInfoDescriptor inputCoderDescriptor,
FlinkFnApi.CoderInfoDescriptor outputCoderDescriptor,
FlinkFnApi.CoderInfoDescriptor timerCoderDescriptor,
Map<String,FlinkFnApi.CoderInfoDescriptor> sideOutputCoderDescriptors) |
Modifier and Type | Method and Description |
---|---|
protected void |
buildTransforms(org.apache.beam.model.pipeline.v1.RunnerApi.Components.Builder componentsBuilder) |
protected Optional<org.apache.beam.model.pipeline.v1.RunnerApi.Coder> |
getOptionalTimerCoderProto() |
protected List<org.apache.beam.runners.core.construction.graph.TimerReference> |
getTimers(org.apache.beam.model.pipeline.v1.RunnerApi.Components components) |
close, createJobBundleFactory, flush, notifyNoMoreResults, open, pollResult, process, processTimer, startBundle, takeResult
public BeamDataStreamPythonFunctionRunner(String taskName, ProcessPythonEnvironmentManager environmentManager, String headOperatorFunctionUrn, List<FlinkFnApi.UserDefinedDataStreamFunction> userDefinedDataStreamFunctions, @Nullable FlinkMetricContainer flinkMetricContainer, @Nullable KeyedStateBackend<?> keyedStateBackend, @Nullable OperatorStateBackend operatorStateBackend, @Nullable TypeSerializer<?> keySerializer, @Nullable TypeSerializer<?> namespaceSerializer, @Nullable TimerRegistration timerRegistration, MemoryManager memoryManager, double managedMemoryFraction, FlinkFnApi.CoderInfoDescriptor inputCoderDescriptor, FlinkFnApi.CoderInfoDescriptor outputCoderDescriptor, @Nullable FlinkFnApi.CoderInfoDescriptor timerCoderDescriptor, Map<String,FlinkFnApi.CoderInfoDescriptor> sideOutputCoderDescriptors)
protected void buildTransforms(org.apache.beam.model.pipeline.v1.RunnerApi.Components.Builder componentsBuilder)
buildTransforms
in class BeamPythonFunctionRunner
protected List<org.apache.beam.runners.core.construction.graph.TimerReference> getTimers(org.apache.beam.model.pipeline.v1.RunnerApi.Components components)
getTimers
in class BeamPythonFunctionRunner
protected Optional<org.apache.beam.model.pipeline.v1.RunnerApi.Coder> getOptionalTimerCoderProto()
getOptionalTimerCoderProto
in class BeamPythonFunctionRunner
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.