Package org.apache.beam.runners.fnexecution.control
package org.apache.beam.runners.fnexecution.control
Utilities for a Beam runner to interact with the Fn API
Control Service via java abstractions.-
ClassDescriptionA handler which is invoked when the SDK returns
BeamFnApi.DelayedBundleApplications as part of the bundle completion.Utility methods for creatingBundleCheckpointHandlers.ABundleCheckpointHandlerwhich usesTimerInternals.TimerDataandValueStateto rescheduleBeamFnApi.DelayedBundleApplication.A handler for the runner when a finalization request has been received.Utility methods for creatingBundleFinalizationHandlers.A handler for bundle progress messages, both during bundle execution and on its completion.A handler which is invoked whenever an active bundle is split.A pool of control clients that brokers incoming SDK harness connections (in the form ofInstructionRequestHandlers.A sink forInstructionRequestHandlerskeyed by worker id.A source ofInstructionRequestHandlers.Implementation of aExecutableStageContext.AJobBundleFactoryfor which the implementation can specify a customEnvironmentFactoryfor environment management.A container for EnvironmentFactory and its corresponding Grpc servers.Holder for anSdkHarnessClientalong with its associated state and data servers.The context required in order to executestages.CreatesExecutableStageContextinstances.A client for the control plane of an SDK harness, which can issue requests to it over the Fn API.A Fn API control service which adds incoming SDK harness connections to a sink.Interface for any function that can handle a Fn APIBeamFnApi.InstructionRequest.A factory that has all job-scoped information, and can be combined with stage-scoped information to create aStageBundleFactory.AControlClientPoolbacked by a client map.A factory that can create output receivers during an executable stage.Utility methods for creatingBeamFnApi.ProcessBundleDescriptorinstances.ProcessBundleDescriptors.BagUserStateSpec<K,V, W extends BoundedWindow> A container type storing references to the key, value, and windowCoderused when handling bag user state requests.ProcessBundleDescriptors.SideInputSpec<T,W extends BoundedWindow> A container type storing references to the value, and windowCoderused when handling side input state requests.ProcessBundleDescriptors.TimerSpec<K,V, W extends BoundedWindow> A container type storing references to the key, timer and payload coders and the remote input destination used when handling timer requests.ExecutableStageContext.Factorywhich counts ExecutableStageContext reference for book keeping.Interface for creator which extends Serializable.A bundle capable of handling input data elements for abundle descriptorby forwarding them to a remote environment for processing.A pair ofCoderandFnDataReceiverwhich can be registered to receive elements for aLogicalEndpoint.A high-level client for an SDK harness.Deprecated.A bundle factory scoped to a particularExecutableStage, which has all of the resources it needs to provide newRemoteBundles.A factory that passes timers toTimerReceiverFactory.timerDataConsumer.
DefaultJobBundleFactorywhen appropriate if theEnvironmentFactoryis aDockerEnvironmentFactory, or create anInProcessJobBundleFactoryand inline the creation of the environment if appropriate.