Struct google_cloud_pubsub::topic::Topic
source · [−]pub struct Topic { /* private fields */ }Expand description
Topic is a reference to a PubSub topic.
The methods of Topic are safe for use by multiple tasks.
Implementations
sourceimpl Topic
impl Topic
sourcepub fn fully_qualified_name(&self) -> &str
pub fn fully_qualified_name(&self) -> &str
fully_qualified_name returns the printable globally unique name for the topic.
pub fn new_publisher(&self, config: Option<PublisherConfig>) -> Publisher
sourcepub async fn create(
&self,
cfg: Option<TopicConfig>,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<(), Status>
pub async fn create(
&self,
cfg: Option<TopicConfig>,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<(), Status>
create creates the topic.
sourcepub async fn delete(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<(), Status>
pub async fn delete(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<(), Status>
delete deletes the topic.
sourcepub async fn exists(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<bool, Status>
pub async fn exists(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<bool, Status>
exists reports whether the topic exists on the server.
sourcepub async fn subscriptions(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<Vec<Subscription>, Status>
pub async fn subscriptions(
&self,
cancel: Option<CancellationToken>,
retry: Option<RetrySetting>
) -> Result<Vec<Subscription>, Status>
Subscriptions returns an iterator which returns the subscriptions for this topic.
Trait Implementations
Auto Trait Implementations
impl !RefUnwindSafe for Topic
impl Send for Topic
impl Sync for Topic
impl Unpin for Topic
impl !UnwindSafe for Topic
Blanket Implementations
sourceimpl<T> BorrowMut<T> for T where
T: ?Sized,
impl<T> BorrowMut<T> for T where
T: ?Sized,
const: unstable · sourcefn borrow_mut(&mut self) -> &mut T
fn borrow_mut(&mut self) -> &mut T
Mutably borrows from an owned value. Read more
sourceimpl<T> Instrument for T
impl<T> Instrument for T
sourcefn instrument(self, span: Span) -> Instrumented<Self>
fn instrument(self, span: Span) -> Instrumented<Self>
sourcefn in_current_span(self) -> Instrumented<Self>
fn in_current_span(self) -> Instrumented<Self>
sourceimpl<T> IntoRequest<T> for T
impl<T> IntoRequest<T> for T
sourcefn into_request(self) -> Request<T>
fn into_request(self) -> Request<T>
Wrap the input message T in a tonic::Request
impl<V, T> VZip<V> for T where
V: MultiLane<T>,
impl<V, T> VZip<V> for T where
V: MultiLane<T>,
fn vzip(self) -> V
sourceimpl<T> WithSubscriber for T
impl<T> WithSubscriber for T
sourcefn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self> where
S: Into<Dispatch>,
fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self> where
S: Into<Dispatch>,
Attaches the provided Subscriber to this type, returning a
WithDispatch wrapper. Read more
sourcefn with_current_subscriber(self) -> WithDispatch<Self>
fn with_current_subscriber(self) -> WithDispatch<Self>
Attaches the current default Subscriber to this type, returning a
WithDispatch wrapper. Read more