public class GrpcDataService extends org.apache.beam.model.fnexecution.v1.BeamFnDataGrpc.BeamFnDataImplBase implements FnService, FnDataService
FnDataService implemented via gRPC.
 This service allows for multiple clients to transmit BeamFnApi.Elements messages.
 
This service transmits all outgoing BeamFnApi.Elements messages to the first client
 that connects.
| Constructor and Description | 
|---|
| GrpcDataService()Deprecated. 
 This constructor is for migrating Dataflow purpose only. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | close(). | 
| static GrpcDataService | create(PipelineOptions options,
      java.util.concurrent.ExecutorService executor,
      OutboundObserverFactory outboundObserverFactory) | 
| BeamFnDataOutboundAggregator | createOutboundAggregator(java.util.function.Supplier<java.lang.String> processBundleRequestIdSupplier,
                        boolean collectElementsIfNoFlushes)Creates a  BeamFnDataOutboundAggregatorfor buffering and sending outbound data and
 timers over the data plane. | 
| org.apache.beam.vendor.grpc.v1p54p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> | data(org.apache.beam.vendor.grpc.v1p54p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> outboundElementObserver) | 
| void | registerReceiver(java.lang.String instructionId,
                CloseableFnDataReceiver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> observer)Registers a receiver for the provided instruction id. | 
| void | unregisterReceiver(java.lang.String instructionId)Receivers are only expected to be unregistered when bundle processing has completed
 successfully. | 
bindService@Deprecated public GrpcDataService()
public static GrpcDataService create(PipelineOptions options, java.util.concurrent.ExecutorService executor, OutboundObserverFactory outboundObserverFactory)
public org.apache.beam.vendor.grpc.v1p54p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> data(org.apache.beam.vendor.grpc.v1p54p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> outboundElementObserver)
data in interface org.apache.beam.model.fnexecution.v1.BeamFnDataGrpc.AsyncServicepublic void close()
           throws java.lang.Exception
FnServiceThere should be no more calls to any service method by the time a call to FnService.close()
 begins. Specifically, this means that a Server that this service is bound to should have
 completed a call to the Server.shutdown()
 method, and all future incoming calls will be rejected.
public void registerReceiver(java.lang.String instructionId,
                             CloseableFnDataReceiver<org.apache.beam.model.fnexecution.v1.BeamFnApi.Elements> observer)
FnDataServiceThe receiver is not required to be thread safe.
Receivers for successfully processed bundles must be unregistered. See FnDataService.unregisterReceiver(java.lang.String) for details.
 
Any failure during FnDataReceiver.accept(T) will mark the provided instructionId as invalid and will ignore any future data. It is expected that if a bundle
 fails during processing then the failure will become visible to the FnDataService
 during a future FnDataReceiver.accept(T) invocation.
registerReceiver in interface FnDataServicepublic void unregisterReceiver(java.lang.String instructionId)
FnDataServiceIt is expected that if a bundle fails during processing then the failure will become visible
 to the FnDataService during a future FnDataReceiver.accept(T) invocation.
unregisterReceiver in interface FnDataServicepublic BeamFnDataOutboundAggregator createOutboundAggregator(java.util.function.Supplier<java.lang.String> processBundleRequestIdSupplier, boolean collectElementsIfNoFlushes)
FnDataServiceBeamFnDataOutboundAggregator for buffering and sending outbound data and
 timers over the data plane. It is important that BeamFnDataOutboundAggregator.sendOrCollectBufferedDataAndFinishOutboundStreams() is called on
 the returned BeamFnDataOutboundAggregator at the end of each bundle. If
 collectElementsIfNoFlushes is set to true, BeamFnDataOutboundAggregator.sendOrCollectBufferedDataAndFinishOutboundStreams() returns the
 buffered elements instead of sending it through the outbound StreamObserver if there's no
 previous flush.
 Closing the returned aggregator signals the end of the streams.
The returned aggregator is not thread safe.
createOutboundAggregator in interface FnDataService