[][src]Struct pulsar::message::proto::BaseCommand

pub struct BaseCommand {
    pub type_: i32,
    pub connect: Option<CommandConnect>,
    pub connected: Option<CommandConnected>,
    pub subscribe: Option<CommandSubscribe>,
    pub producer: Option<CommandProducer>,
    pub send: Option<CommandSend>,
    pub send_receipt: Option<CommandSendReceipt>,
    pub send_error: Option<CommandSendError>,
    pub message: Option<CommandMessage>,
    pub ack: Option<CommandAck>,
    pub flow: Option<CommandFlow>,
    pub unsubscribe: Option<CommandUnsubscribe>,
    pub success: Option<CommandSuccess>,
    pub error: Option<CommandError>,
    pub close_producer: Option<CommandCloseProducer>,
    pub close_consumer: Option<CommandCloseConsumer>,
    pub producer_success: Option<CommandProducerSuccess>,
    pub ping: Option<CommandPing>,
    pub pong: Option<CommandPong>,
    pub redeliver_unacknowledged_messages: Option<CommandRedeliverUnacknowledgedMessages>,
    pub partition_metadata: Option<CommandPartitionedTopicMetadata>,
    pub partition_metadata_response: Option<CommandPartitionedTopicMetadataResponse>,
    pub lookup_topic: Option<CommandLookupTopic>,
    pub lookup_topic_response: Option<CommandLookupTopicResponse>,
    pub consumer_stats: Option<CommandConsumerStats>,
    pub consumer_stats_response: Option<CommandConsumerStatsResponse>,
    pub reached_end_of_topic: Option<CommandReachedEndOfTopic>,
    pub seek: Option<CommandSeek>,
    pub get_last_message_id: Option<CommandGetLastMessageId>,
    pub get_last_message_id_response: Option<CommandGetLastMessageIdResponse>,
    pub active_consumer_change: Option<CommandActiveConsumerChange>,
    pub get_topics_of_namespace: Option<CommandGetTopicsOfNamespace>,
    pub get_topics_of_namespace_response: Option<CommandGetTopicsOfNamespaceResponse>,
    pub get_schema: Option<CommandGetSchema>,
    pub get_schema_response: Option<CommandGetSchemaResponse>,
}

Fields

type_: i32connect: Option<CommandConnect>connected: Option<CommandConnected>subscribe: Option<CommandSubscribe>producer: Option<CommandProducer>send: Option<CommandSend>send_receipt: Option<CommandSendReceipt>send_error: Option<CommandSendError>message: Option<CommandMessage>ack: Option<CommandAck>flow: Option<CommandFlow>unsubscribe: Option<CommandUnsubscribe>success: Option<CommandSuccess>error: Option<CommandError>close_producer: Option<CommandCloseProducer>close_consumer: Option<CommandCloseConsumer>producer_success: Option<CommandProducerSuccess>ping: Option<CommandPing>pong: Option<CommandPong>redeliver_unacknowledged_messages: Option<CommandRedeliverUnacknowledgedMessages>partition_metadata: Option<CommandPartitionedTopicMetadata>partition_metadata_response: Option<CommandPartitionedTopicMetadataResponse>lookup_topic: Option<CommandLookupTopic>lookup_topic_response: Option<CommandLookupTopicResponse>consumer_stats: Option<CommandConsumerStats>consumer_stats_response: Option<CommandConsumerStatsResponse>reached_end_of_topic: Option<CommandReachedEndOfTopic>seek: Option<CommandSeek>get_last_message_id: Option<CommandGetLastMessageId>get_last_message_id_response: Option<CommandGetLastMessageIdResponse>active_consumer_change: Option<CommandActiveConsumerChange>get_topics_of_namespace: Option<CommandGetTopicsOfNamespace>get_topics_of_namespace_response: Option<CommandGetTopicsOfNamespaceResponse>get_schema: Option<CommandGetSchema>get_schema_response: Option<CommandGetSchemaResponse>

Implementations

impl BaseCommand[src]

pub fn type_(&self) -> Type[src]

Returns the enum value of type_, or the default if the field is set to an invalid enum value.

pub fn set_type_(&mut self, value: Type)[src]

Sets type_ to the provided enum value.

Trait Implementations

impl Clone for BaseCommand[src]

impl Debug for BaseCommand[src]

impl Default for BaseCommand[src]

impl Message for BaseCommand[src]

impl PartialEq<BaseCommand> for BaseCommand[src]

impl StructuralPartialEq for BaseCommand[src]

Auto Trait Implementations

Blanket Implementations

impl<T> Any for T where
    T: 'static + ?Sized
[src]

impl<T> Borrow<T> for T where
    T: ?Sized
[src]

impl<T> BorrowMut<T> for T where
    T: ?Sized
[src]

impl<T> From<T> for T[src]

impl<T, U> Into<U> for T where
    U: From<T>, 
[src]

impl<T> ToOwned for T where
    T: Clone
[src]

type Owned = T

The resulting type after obtaining ownership.

impl<T, U> TryFrom<U> for T where
    U: Into<T>, 
[src]

type Error = Infallible

The type returned in the event of a conversion error.

impl<T, U> TryInto<U> for T where
    U: TryFrom<T>, 
[src]

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.

impl<V, T> VZip<V> for T where
    V: MultiLane<T>,