c

com.google.pubsub.v1.pubsub

DefaultSubscriberClient

final class DefaultSubscriberClient extends SubscriberClient

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. DefaultSubscriberClient
  2. SubscriberClient
  3. AkkaGrpcClient
  4. SubscriberClientPowerApi
  5. Subscriber
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new DefaultSubscriberClient(settings: GrpcClientSettings)(implicit sys: ClassicActorSystemProvider)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def acknowledge(in: AcknowledgeRequest): Future[Empty]

    For access to method metadata use the parameterless version of acknowledge

    For access to method metadata use the parameterless version of acknowledge

    Definition Classes
    DefaultSubscriberClientSubscriber
  5. def acknowledge(): SingleResponseRequestBuilder[AcknowledgeRequest, Empty]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer acknowledge(com.google.pubsub.v1.pubsub.AcknowledgeRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  6. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native() @HotSpotIntrinsicCandidate()
  8. def close(): Future[Done]
    Definition Classes
    DefaultSubscriberClient → AkkaGrpcClient
  9. def closed: Future[Done]
    Definition Classes
    DefaultSubscriberClient → AkkaGrpcClient
  10. def createSnapshot(in: CreateSnapshotRequest): Future[Snapshot]

    For access to method metadata use the parameterless version of createSnapshot

    For access to method metadata use the parameterless version of createSnapshot

    Definition Classes
    DefaultSubscriberClientSubscriber
  11. def createSnapshot(): SingleResponseRequestBuilder[CreateSnapshotRequest, Snapshot]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer createSnapshot(com.google.pubsub.v1.pubsub.CreateSnapshotRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  12. def createSubscription(in: Subscription): Future[Subscription]

    For access to method metadata use the parameterless version of createSubscription

    For access to method metadata use the parameterless version of createSubscription

    Definition Classes
    DefaultSubscriberClientSubscriber
  13. def createSubscription(): SingleResponseRequestBuilder[Subscription, Subscription]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer createSubscription(com.google.pubsub.v1.pubsub.Subscription) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  14. def deleteSnapshot(in: DeleteSnapshotRequest): Future[Empty]

    For access to method metadata use the parameterless version of deleteSnapshot

    For access to method metadata use the parameterless version of deleteSnapshot

    Definition Classes
    DefaultSubscriberClientSubscriber
  15. def deleteSnapshot(): SingleResponseRequestBuilder[DeleteSnapshotRequest, Empty]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer deleteSnapshot(com.google.pubsub.v1.pubsub.DeleteSnapshotRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  16. def deleteSubscription(in: DeleteSubscriptionRequest): Future[Empty]

    For access to method metadata use the parameterless version of deleteSubscription

    For access to method metadata use the parameterless version of deleteSubscription

    Definition Classes
    DefaultSubscriberClientSubscriber
  17. def deleteSubscription(): SingleResponseRequestBuilder[DeleteSubscriptionRequest, Empty]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer deleteSubscription(com.google.pubsub.v1.pubsub.DeleteSubscriptionRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  18. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  19. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  20. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  21. def getSnapshot(in: GetSnapshotRequest): Future[Snapshot]

    For access to method metadata use the parameterless version of getSnapshot

    For access to method metadata use the parameterless version of getSnapshot

    Definition Classes
    DefaultSubscriberClientSubscriber
  22. def getSnapshot(): SingleResponseRequestBuilder[GetSnapshotRequest, Snapshot]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer getSnapshot(com.google.pubsub.v1.pubsub.GetSnapshotRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  23. def getSubscription(in: GetSubscriptionRequest): Future[Subscription]

    For access to method metadata use the parameterless version of getSubscription

    For access to method metadata use the parameterless version of getSubscription

    Definition Classes
    DefaultSubscriberClientSubscriber
  24. def getSubscription(): SingleResponseRequestBuilder[GetSubscriptionRequest, Subscription]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer getSubscription(com.google.pubsub.v1.pubsub.GetSubscriptionRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  25. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  26. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  27. def listSnapshots(in: ListSnapshotsRequest): Future[ListSnapshotsResponse]

    For access to method metadata use the parameterless version of listSnapshots

    For access to method metadata use the parameterless version of listSnapshots

    Definition Classes
    DefaultSubscriberClientSubscriber
  28. def listSnapshots(): SingleResponseRequestBuilder[ListSnapshotsRequest, ListSnapshotsResponse]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer listSnapshots(com.google.pubsub.v1.pubsub.ListSnapshotsRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  29. def listSubscriptions(in: ListSubscriptionsRequest): Future[ListSubscriptionsResponse]

    For access to method metadata use the parameterless version of listSubscriptions

    For access to method metadata use the parameterless version of listSubscriptions

    Definition Classes
    DefaultSubscriberClientSubscriber
  30. def listSubscriptions(): SingleResponseRequestBuilder[ListSubscriptionsRequest, ListSubscriptionsResponse]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer listSubscriptions(com.google.pubsub.v1.pubsub.ListSubscriptionsRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  31. def modifyAckDeadline(in: ModifyAckDeadlineRequest): Future[Empty]

    For access to method metadata use the parameterless version of modifyAckDeadline

    For access to method metadata use the parameterless version of modifyAckDeadline

    Definition Classes
    DefaultSubscriberClientSubscriber
  32. def modifyAckDeadline(): SingleResponseRequestBuilder[ModifyAckDeadlineRequest, Empty]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer modifyAckDeadline(com.google.pubsub.v1.pubsub.ModifyAckDeadlineRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  33. def modifyPushConfig(in: ModifyPushConfigRequest): Future[Empty]

    For access to method metadata use the parameterless version of modifyPushConfig

    For access to method metadata use the parameterless version of modifyPushConfig

    Definition Classes
    DefaultSubscriberClientSubscriber
  34. def modifyPushConfig(): SingleResponseRequestBuilder[ModifyPushConfigRequest, Empty]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer modifyPushConfig(com.google.pubsub.v1.pubsub.ModifyPushConfigRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  35. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  36. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  37. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  38. def pull(in: PullRequest): Future[PullResponse]

    For access to method metadata use the parameterless version of pull

    For access to method metadata use the parameterless version of pull

    Definition Classes
    DefaultSubscriberClientSubscriber
  39. def pull(): SingleResponseRequestBuilder[PullRequest, PullResponse]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer pull(com.google.pubsub.v1.pubsub.PullRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  40. def seek(in: SeekRequest): Future[SeekResponse]

    For access to method metadata use the parameterless version of seek

    For access to method metadata use the parameterless version of seek

    Definition Classes
    DefaultSubscriberClientSubscriber
  41. def seek(): SingleResponseRequestBuilder[SeekRequest, SeekResponse]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer seek(com.google.pubsub.v1.pubsub.SeekRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  42. def streamingPull(in: Source[StreamingPullRequest, NotUsed]): Source[StreamingPullResponse, NotUsed]

    For access to method metadata use the parameterless version of streamingPull

    For access to method metadata use the parameterless version of streamingPull

    Definition Classes
    DefaultSubscriberClientSubscriber
  43. def streamingPull(): StreamResponseRequestBuilder[Source[StreamingPullRequest, NotUsed], StreamingPullResponse]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer streamingPull(akka.stream.scaladsl.Source[com.google.pubsub.v1.pubsub.StreamingPullRequest, akka.NotUsed]) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  44. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  45. def toString(): String
    Definition Classes
    AnyRef → Any
  46. def updateSnapshot(in: UpdateSnapshotRequest): Future[Snapshot]

    For access to method metadata use the parameterless version of updateSnapshot

    For access to method metadata use the parameterless version of updateSnapshot

    Definition Classes
    DefaultSubscriberClientSubscriber
  47. def updateSnapshot(): SingleResponseRequestBuilder[UpdateSnapshotRequest, Snapshot]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer updateSnapshot(com.google.pubsub.v1.pubsub.UpdateSnapshotRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  48. def updateSubscription(in: UpdateSubscriptionRequest): Future[Subscription]

    For access to method metadata use the parameterless version of updateSubscription

    For access to method metadata use the parameterless version of updateSubscription

    Definition Classes
    DefaultSubscriberClientSubscriber
  49. def updateSubscription(): SingleResponseRequestBuilder[UpdateSubscriptionRequest, Subscription]

    Lower level "lifted" version of the method, giving access to request metadata etc.

    Lower level "lifted" version of the method, giving access to request metadata etc. prefer updateSubscription(com.google.pubsub.v1.pubsub.UpdateSubscriptionRequest) if possible.

    Definition Classes
    DefaultSubscriberClientSubscriberClientPowerApi
  50. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  51. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  52. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] ) @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from SubscriberClient

Inherited from AkkaGrpcClient

Inherited from SubscriberClientPowerApi

Inherited from Subscriber

Inherited from AnyRef

Inherited from Any

Ungrouped