Class BaseCommand
- java.lang.Object
-
- org.apache.pulsar.common.api.proto.BaseCommand
-
public final class BaseCommand extends java.lang.Object
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static classBaseCommand.Type
-
Constructor Summary
Constructors Constructor Description BaseCommand()
-
Method Summary
-
-
-
Method Detail
-
hasType
public boolean hasType()
-
getType
public BaseCommand.Type getType()
-
setType
public BaseCommand setType(BaseCommand.Type type)
-
clearType
public BaseCommand clearType()
-
hasConnect
public boolean hasConnect()
-
getConnect
public CommandConnect getConnect()
-
setConnect
public CommandConnect setConnect()
-
clearConnect
public BaseCommand clearConnect()
-
hasConnected
public boolean hasConnected()
-
getConnected
public CommandConnected getConnected()
-
setConnected
public CommandConnected setConnected()
-
clearConnected
public BaseCommand clearConnected()
-
hasSubscribe
public boolean hasSubscribe()
-
getSubscribe
public CommandSubscribe getSubscribe()
-
setSubscribe
public CommandSubscribe setSubscribe()
-
clearSubscribe
public BaseCommand clearSubscribe()
-
hasProducer
public boolean hasProducer()
-
getProducer
public CommandProducer getProducer()
-
setProducer
public CommandProducer setProducer()
-
clearProducer
public BaseCommand clearProducer()
-
hasSend
public boolean hasSend()
-
getSend
public CommandSend getSend()
-
setSend
public CommandSend setSend()
-
clearSend
public BaseCommand clearSend()
-
hasSendReceipt
public boolean hasSendReceipt()
-
getSendReceipt
public CommandSendReceipt getSendReceipt()
-
setSendReceipt
public CommandSendReceipt setSendReceipt()
-
clearSendReceipt
public BaseCommand clearSendReceipt()
-
hasSendError
public boolean hasSendError()
-
getSendError
public CommandSendError getSendError()
-
setSendError
public CommandSendError setSendError()
-
clearSendError
public BaseCommand clearSendError()
-
hasMessage
public boolean hasMessage()
-
getMessage
public CommandMessage getMessage()
-
setMessage
public CommandMessage setMessage()
-
clearMessage
public BaseCommand clearMessage()
-
hasAck
public boolean hasAck()
-
getAck
public CommandAck getAck()
-
setAck
public CommandAck setAck()
-
clearAck
public BaseCommand clearAck()
-
hasFlow
public boolean hasFlow()
-
getFlow
public CommandFlow getFlow()
-
setFlow
public CommandFlow setFlow()
-
clearFlow
public BaseCommand clearFlow()
-
hasUnsubscribe
public boolean hasUnsubscribe()
-
getUnsubscribe
public CommandUnsubscribe getUnsubscribe()
-
setUnsubscribe
public CommandUnsubscribe setUnsubscribe()
-
clearUnsubscribe
public BaseCommand clearUnsubscribe()
-
hasSuccess
public boolean hasSuccess()
-
getSuccess
public CommandSuccess getSuccess()
-
setSuccess
public CommandSuccess setSuccess()
-
clearSuccess
public BaseCommand clearSuccess()
-
hasError
public boolean hasError()
-
getError
public CommandError getError()
-
setError
public CommandError setError()
-
clearError
public BaseCommand clearError()
-
hasCloseProducer
public boolean hasCloseProducer()
-
getCloseProducer
public CommandCloseProducer getCloseProducer()
-
setCloseProducer
public CommandCloseProducer setCloseProducer()
-
clearCloseProducer
public BaseCommand clearCloseProducer()
-
hasCloseConsumer
public boolean hasCloseConsumer()
-
getCloseConsumer
public CommandCloseConsumer getCloseConsumer()
-
setCloseConsumer
public CommandCloseConsumer setCloseConsumer()
-
clearCloseConsumer
public BaseCommand clearCloseConsumer()
-
hasProducerSuccess
public boolean hasProducerSuccess()
-
getProducerSuccess
public CommandProducerSuccess getProducerSuccess()
-
setProducerSuccess
public CommandProducerSuccess setProducerSuccess()
-
clearProducerSuccess
public BaseCommand clearProducerSuccess()
-
hasPing
public boolean hasPing()
-
getPing
public CommandPing getPing()
-
setPing
public CommandPing setPing()
-
clearPing
public BaseCommand clearPing()
-
hasPong
public boolean hasPong()
-
getPong
public CommandPong getPong()
-
setPong
public CommandPong setPong()
-
clearPong
public BaseCommand clearPong()
-
hasRedeliverUnacknowledgedMessages
public boolean hasRedeliverUnacknowledgedMessages()
-
getRedeliverUnacknowledgedMessages
public CommandRedeliverUnacknowledgedMessages getRedeliverUnacknowledgedMessages()
-
setRedeliverUnacknowledgedMessages
public CommandRedeliverUnacknowledgedMessages setRedeliverUnacknowledgedMessages()
-
clearRedeliverUnacknowledgedMessages
public BaseCommand clearRedeliverUnacknowledgedMessages()
-
hasPartitionMetadata
public boolean hasPartitionMetadata()
-
getPartitionMetadata
public CommandPartitionedTopicMetadata getPartitionMetadata()
-
setPartitionMetadata
public CommandPartitionedTopicMetadata setPartitionMetadata()
-
clearPartitionMetadata
public BaseCommand clearPartitionMetadata()
-
hasPartitionMetadataResponse
public boolean hasPartitionMetadataResponse()
-
getPartitionMetadataResponse
public CommandPartitionedTopicMetadataResponse getPartitionMetadataResponse()
-
setPartitionMetadataResponse
public CommandPartitionedTopicMetadataResponse setPartitionMetadataResponse()
-
clearPartitionMetadataResponse
public BaseCommand clearPartitionMetadataResponse()
-
hasLookupTopic
public boolean hasLookupTopic()
-
getLookupTopic
public CommandLookupTopic getLookupTopic()
-
setLookupTopic
public CommandLookupTopic setLookupTopic()
-
clearLookupTopic
public BaseCommand clearLookupTopic()
-
hasLookupTopicResponse
public boolean hasLookupTopicResponse()
-
getLookupTopicResponse
public CommandLookupTopicResponse getLookupTopicResponse()
-
setLookupTopicResponse
public CommandLookupTopicResponse setLookupTopicResponse()
-
clearLookupTopicResponse
public BaseCommand clearLookupTopicResponse()
-
hasConsumerStats
public boolean hasConsumerStats()
-
getConsumerStats
public CommandConsumerStats getConsumerStats()
-
setConsumerStats
public CommandConsumerStats setConsumerStats()
-
clearConsumerStats
public BaseCommand clearConsumerStats()
-
hasConsumerStatsResponse
public boolean hasConsumerStatsResponse()
-
getConsumerStatsResponse
public CommandConsumerStatsResponse getConsumerStatsResponse()
-
setConsumerStatsResponse
public CommandConsumerStatsResponse setConsumerStatsResponse()
-
clearConsumerStatsResponse
public BaseCommand clearConsumerStatsResponse()
-
hasReachedEndOfTopic
public boolean hasReachedEndOfTopic()
-
getReachedEndOfTopic
public CommandReachedEndOfTopic getReachedEndOfTopic()
-
setReachedEndOfTopic
public CommandReachedEndOfTopic setReachedEndOfTopic()
-
clearReachedEndOfTopic
public BaseCommand clearReachedEndOfTopic()
-
hasSeek
public boolean hasSeek()
-
getSeek
public CommandSeek getSeek()
-
setSeek
public CommandSeek setSeek()
-
clearSeek
public BaseCommand clearSeek()
-
hasGetLastMessageId
public boolean hasGetLastMessageId()
-
getGetLastMessageId
public CommandGetLastMessageId getGetLastMessageId()
-
setGetLastMessageId
public CommandGetLastMessageId setGetLastMessageId()
-
clearGetLastMessageId
public BaseCommand clearGetLastMessageId()
-
hasGetLastMessageIdResponse
public boolean hasGetLastMessageIdResponse()
-
getGetLastMessageIdResponse
public CommandGetLastMessageIdResponse getGetLastMessageIdResponse()
-
setGetLastMessageIdResponse
public CommandGetLastMessageIdResponse setGetLastMessageIdResponse()
-
clearGetLastMessageIdResponse
public BaseCommand clearGetLastMessageIdResponse()
-
hasActiveConsumerChange
public boolean hasActiveConsumerChange()
-
getActiveConsumerChange
public CommandActiveConsumerChange getActiveConsumerChange()
-
setActiveConsumerChange
public CommandActiveConsumerChange setActiveConsumerChange()
-
clearActiveConsumerChange
public BaseCommand clearActiveConsumerChange()
-
hasGetTopicsOfNamespace
public boolean hasGetTopicsOfNamespace()
-
getGetTopicsOfNamespace
public CommandGetTopicsOfNamespace getGetTopicsOfNamespace()
-
setGetTopicsOfNamespace
public CommandGetTopicsOfNamespace setGetTopicsOfNamespace()
-
clearGetTopicsOfNamespace
public BaseCommand clearGetTopicsOfNamespace()
-
hasGetTopicsOfNamespaceResponse
public boolean hasGetTopicsOfNamespaceResponse()
-
getGetTopicsOfNamespaceResponse
public CommandGetTopicsOfNamespaceResponse getGetTopicsOfNamespaceResponse()
-
setGetTopicsOfNamespaceResponse
public CommandGetTopicsOfNamespaceResponse setGetTopicsOfNamespaceResponse()
-
clearGetTopicsOfNamespaceResponse
public BaseCommand clearGetTopicsOfNamespaceResponse()
-
hasGetSchema
public boolean hasGetSchema()
-
getGetSchema
public CommandGetSchema getGetSchema()
-
setGetSchema
public CommandGetSchema setGetSchema()
-
clearGetSchema
public BaseCommand clearGetSchema()
-
hasGetSchemaResponse
public boolean hasGetSchemaResponse()
-
getGetSchemaResponse
public CommandGetSchemaResponse getGetSchemaResponse()
-
setGetSchemaResponse
public CommandGetSchemaResponse setGetSchemaResponse()
-
clearGetSchemaResponse
public BaseCommand clearGetSchemaResponse()
-
hasAuthChallenge
public boolean hasAuthChallenge()
-
getAuthChallenge
public CommandAuthChallenge getAuthChallenge()
-
setAuthChallenge
public CommandAuthChallenge setAuthChallenge()
-
clearAuthChallenge
public BaseCommand clearAuthChallenge()
-
hasAuthResponse
public boolean hasAuthResponse()
-
getAuthResponse
public CommandAuthResponse getAuthResponse()
-
setAuthResponse
public CommandAuthResponse setAuthResponse()
-
clearAuthResponse
public BaseCommand clearAuthResponse()
-
hasAckResponse
public boolean hasAckResponse()
-
getAckResponse
public CommandAckResponse getAckResponse()
-
setAckResponse
public CommandAckResponse setAckResponse()
-
clearAckResponse
public BaseCommand clearAckResponse()
-
hasGetOrCreateSchema
public boolean hasGetOrCreateSchema()
-
getGetOrCreateSchema
public CommandGetOrCreateSchema getGetOrCreateSchema()
-
setGetOrCreateSchema
public CommandGetOrCreateSchema setGetOrCreateSchema()
-
clearGetOrCreateSchema
public BaseCommand clearGetOrCreateSchema()
-
hasGetOrCreateSchemaResponse
public boolean hasGetOrCreateSchemaResponse()
-
getGetOrCreateSchemaResponse
public CommandGetOrCreateSchemaResponse getGetOrCreateSchemaResponse()
-
setGetOrCreateSchemaResponse
public CommandGetOrCreateSchemaResponse setGetOrCreateSchemaResponse()
-
clearGetOrCreateSchemaResponse
public BaseCommand clearGetOrCreateSchemaResponse()
-
hasNewTxn
public boolean hasNewTxn()
-
getNewTxn
public CommandNewTxn getNewTxn()
-
setNewTxn
public CommandNewTxn setNewTxn()
-
clearNewTxn
public BaseCommand clearNewTxn()
-
hasNewTxnResponse
public boolean hasNewTxnResponse()
-
getNewTxnResponse
public CommandNewTxnResponse getNewTxnResponse()
-
setNewTxnResponse
public CommandNewTxnResponse setNewTxnResponse()
-
clearNewTxnResponse
public BaseCommand clearNewTxnResponse()
-
hasAddPartitionToTxn
public boolean hasAddPartitionToTxn()
-
getAddPartitionToTxn
public CommandAddPartitionToTxn getAddPartitionToTxn()
-
setAddPartitionToTxn
public CommandAddPartitionToTxn setAddPartitionToTxn()
-
clearAddPartitionToTxn
public BaseCommand clearAddPartitionToTxn()
-
hasAddPartitionToTxnResponse
public boolean hasAddPartitionToTxnResponse()
-
getAddPartitionToTxnResponse
public CommandAddPartitionToTxnResponse getAddPartitionToTxnResponse()
-
setAddPartitionToTxnResponse
public CommandAddPartitionToTxnResponse setAddPartitionToTxnResponse()
-
clearAddPartitionToTxnResponse
public BaseCommand clearAddPartitionToTxnResponse()
-
hasAddSubscriptionToTxn
public boolean hasAddSubscriptionToTxn()
-
getAddSubscriptionToTxn
public CommandAddSubscriptionToTxn getAddSubscriptionToTxn()
-
setAddSubscriptionToTxn
public CommandAddSubscriptionToTxn setAddSubscriptionToTxn()
-
clearAddSubscriptionToTxn
public BaseCommand clearAddSubscriptionToTxn()
-
hasAddSubscriptionToTxnResponse
public boolean hasAddSubscriptionToTxnResponse()
-
getAddSubscriptionToTxnResponse
public CommandAddSubscriptionToTxnResponse getAddSubscriptionToTxnResponse()
-
setAddSubscriptionToTxnResponse
public CommandAddSubscriptionToTxnResponse setAddSubscriptionToTxnResponse()
-
clearAddSubscriptionToTxnResponse
public BaseCommand clearAddSubscriptionToTxnResponse()
-
hasEndTxn
public boolean hasEndTxn()
-
getEndTxn
public CommandEndTxn getEndTxn()
-
setEndTxn
public CommandEndTxn setEndTxn()
-
clearEndTxn
public BaseCommand clearEndTxn()
-
hasEndTxnResponse
public boolean hasEndTxnResponse()
-
getEndTxnResponse
public CommandEndTxnResponse getEndTxnResponse()
-
setEndTxnResponse
public CommandEndTxnResponse setEndTxnResponse()
-
clearEndTxnResponse
public BaseCommand clearEndTxnResponse()
-
hasEndTxnOnPartition
public boolean hasEndTxnOnPartition()
-
getEndTxnOnPartition
public CommandEndTxnOnPartition getEndTxnOnPartition()
-
setEndTxnOnPartition
public CommandEndTxnOnPartition setEndTxnOnPartition()
-
clearEndTxnOnPartition
public BaseCommand clearEndTxnOnPartition()
-
hasEndTxnOnPartitionResponse
public boolean hasEndTxnOnPartitionResponse()
-
getEndTxnOnPartitionResponse
public CommandEndTxnOnPartitionResponse getEndTxnOnPartitionResponse()
-
setEndTxnOnPartitionResponse
public CommandEndTxnOnPartitionResponse setEndTxnOnPartitionResponse()
-
clearEndTxnOnPartitionResponse
public BaseCommand clearEndTxnOnPartitionResponse()
-
hasEndTxnOnSubscription
public boolean hasEndTxnOnSubscription()
-
getEndTxnOnSubscription
public CommandEndTxnOnSubscription getEndTxnOnSubscription()
-
setEndTxnOnSubscription
public CommandEndTxnOnSubscription setEndTxnOnSubscription()
-
clearEndTxnOnSubscription
public BaseCommand clearEndTxnOnSubscription()
-
hasEndTxnOnSubscriptionResponse
public boolean hasEndTxnOnSubscriptionResponse()
-
getEndTxnOnSubscriptionResponse
public CommandEndTxnOnSubscriptionResponse getEndTxnOnSubscriptionResponse()
-
setEndTxnOnSubscriptionResponse
public CommandEndTxnOnSubscriptionResponse setEndTxnOnSubscriptionResponse()
-
clearEndTxnOnSubscriptionResponse
public BaseCommand clearEndTxnOnSubscriptionResponse()
-
writeTo
public int writeTo(io.netty.buffer.ByteBuf _b)
-
getSerializedSize
public int getSerializedSize()
-
parseFrom
public void parseFrom(io.netty.buffer.ByteBuf _buffer, int _size)
-
clear
public BaseCommand clear()
-
copyFrom
public BaseCommand copyFrom(BaseCommand _other)
-
toByteArray
public byte[] toByteArray()
-
parseFrom
public void parseFrom(byte[] a)
-
-