Class GrpcStateService

java.lang.Object
org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.BeamFnStateImplBase
org.apache.beam.runners.fnexecution.state.GrpcStateService
All Implemented Interfaces:
AutoCloseable, org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.AsyncService, StateDelegator, FnService, org.apache.beam.vendor.grpc.v1p69p0.io.grpc.BindableService

public class GrpcStateService extends org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.BeamFnStateImplBase implements StateDelegator, FnService
An implementation of the Beam Fn State service.
  • Method Summary

    Modifier and Type
    Method
    Description
    void
    .
    Create a new GrpcStateService.
    Registers the supplied handler for the given process bundle instruction id for all BeamFnApi.StateRequests with a matching id.
    org.apache.beam.vendor.grpc.v1p69p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest>
    state(org.apache.beam.vendor.grpc.v1p69p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.StateResponse> responseObserver)
     

    Methods inherited from class org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.BeamFnStateImplBase

    bindService

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface org.apache.beam.vendor.grpc.v1p69p0.io.grpc.BindableService

    bindService
  • Method Details

    • create

      public static GrpcStateService create()
      Create a new GrpcStateService.
    • close

      public void close() throws Exception
      Description copied from interface: FnService
      .

      There 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.

      Specified by:
      close in interface AutoCloseable
      Specified by:
      close in interface FnService
      Throws:
      Exception
    • state

      public org.apache.beam.vendor.grpc.v1p69p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest> state(org.apache.beam.vendor.grpc.v1p69p0.io.grpc.stub.StreamObserver<org.apache.beam.model.fnexecution.v1.BeamFnApi.StateResponse> responseObserver)
      Specified by:
      state in interface org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.AsyncService
    • registerForProcessBundleInstructionId

      public StateDelegator.Registration registerForProcessBundleInstructionId(String processBundleInstructionId, StateRequestHandler handler)
      Description copied from interface: StateDelegator
      Registers the supplied handler for the given process bundle instruction id for all BeamFnApi.StateRequests with a matching id. A handle is returned which allows one to deregister from this StateDelegator.
      Specified by:
      registerForProcessBundleInstructionId in interface StateDelegator