pb

package
v0.1.1 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Jul 9, 2020 License: Apache-2.0 Imports: 6 Imported by: 0

README

go get github.com/gogo/protobuf/protoc-gen-gogofast
go get github.com/gogo/protobuf/proto
go get github.com/gogo/protobuf/gogoproto

Generate code:

protoc -I=. -I=$GOPATH/src -I=$GOPATH/src/github.com/gogo/protobuf/protobuf --gogofast_out=. PulsarApi.proto

Documentation

Index

Constants

View Source
const Default_CommandAckResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAckResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandAck_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAck_TxnidMostBits uint64 = 0
View Source
const Default_CommandActiveConsumerChange_IsActive bool = false
View Source
const Default_CommandAddPartitionToTxnResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAddPartitionToTxnResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandAddPartitionToTxn_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAddPartitionToTxn_TxnidMostBits uint64 = 0
View Source
const Default_CommandAddSubscriptionToTxnResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAddSubscriptionToTxnResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandAddSubscriptionToTxn_TxnidLeastBits uint64 = 0
View Source
const Default_CommandAddSubscriptionToTxn_TxnidMostBits uint64 = 0
View Source
const Default_CommandAuthChallenge_ProtocolVersion int32 = 0
View Source
const Default_CommandAuthResponse_ProtocolVersion int32 = 0
View Source
const Default_CommandConnect_ProtocolVersion int32 = 0
View Source
const Default_CommandConnected_ProtocolVersion int32 = 0
View Source
const Default_CommandEndTxnOnPartitionResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxnOnPartitionResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandEndTxnOnPartition_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxnOnPartition_TxnidMostBits uint64 = 0
View Source
const Default_CommandEndTxnOnSubscriptionResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxnOnSubscriptionResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandEndTxnOnSubscription_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxnOnSubscription_TxnidMostBits uint64 = 0
View Source
const Default_CommandEndTxnResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxnResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandEndTxn_TxnidLeastBits uint64 = 0
View Source
const Default_CommandEndTxn_TxnidMostBits uint64 = 0
View Source
const Default_CommandLookupTopicResponse_Authoritative bool = false
View Source
const Default_CommandLookupTopicResponse_ProxyThroughServiceUrl bool = false
View Source
const Default_CommandLookupTopic_Authoritative bool = false
View Source
const Default_CommandMessage_RedeliveryCount uint32 = 0
View Source
const Default_CommandNewTxnResponse_TxnidLeastBits uint64 = 0
View Source
const Default_CommandNewTxnResponse_TxnidMostBits uint64 = 0
View Source
const Default_CommandNewTxn_TcId uint64 = 0
View Source
const Default_CommandNewTxn_TxnTtlSeconds uint64 = 0
View Source
const Default_CommandProducerSuccess_LastSequenceId int64 = -1
View Source
const Default_CommandProducer_Encrypted bool = false
View Source
const Default_CommandProducer_Epoch uint64 = 0
View Source
const Default_CommandProducer_UserProvidedProducerName bool = true
View Source
const Default_CommandSendReceipt_HighestSequenceId uint64 = 0
View Source
const Default_CommandSend_HighestSequenceId uint64 = 0
View Source
const Default_CommandSend_NumMessages int32 = 1
View Source
const Default_CommandSend_TxnidLeastBits uint64 = 0
View Source
const Default_CommandSend_TxnidMostBits uint64 = 0
View Source
const Default_CommandSubscribe_Durable bool = true
View Source
const Default_CommandSubscribe_ForceTopicCreation bool = true
View Source
const Default_CommandSubscribe_StartMessageRollbackDurationSec uint64 = 0
View Source
const Default_MessageIdData_BatchIndex int32 = -1
View Source
const Default_MessageIdData_Partition int32 = -1
View Source
const Default_MessageMetadata_EventTime uint64 = 0
View Source
const Default_MessageMetadata_HighestSequenceId uint64 = 0
View Source
const Default_MessageMetadata_NumMessagesInBatch int32 = 1
View Source
const Default_MessageMetadata_PartitionKeyB64Encoded bool = false
View Source
const Default_MessageMetadata_TxnidLeastBits uint64 = 0
View Source
const Default_MessageMetadata_TxnidMostBits uint64 = 0
View Source
const Default_MessageMetadata_UncompressedSize uint32 = 0
View Source
const Default_SingleMessageMetadata_CompactedOut bool = false
View Source
const Default_SingleMessageMetadata_EventTime uint64 = 0
View Source
const Default_SingleMessageMetadata_PartitionKeyB64Encoded bool = false

Variables

View Source
var (
	ErrInvalidLengthPulsarApi        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPulsarApi          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPulsarApi = fmt.Errorf("proto: unexpected end of group")
)
View Source
var AuthMethod_name = map[int32]string{
	0: "AuthMethodNone",
	1: "AuthMethodYcaV1",
	2: "AuthMethodAthens",
}
View Source
var AuthMethod_value = map[string]int32{
	"AuthMethodNone":   0,
	"AuthMethodYcaV1":  1,
	"AuthMethodAthens": 2,
}
View Source
var BaseCommand_Type_name = map[int32]string{
	2:  "CONNECT",
	3:  "CONNECTED",
	4:  "SUBSCRIBE",
	5:  "PRODUCER",
	6:  "SEND",
	7:  "SEND_RECEIPT",
	8:  "SEND_ERROR",
	9:  "MESSAGE",
	10: "ACK",
	11: "FLOW",
	12: "UNSUBSCRIBE",
	13: "SUCCESS",
	14: "ERROR",
	15: "CLOSE_PRODUCER",
	16: "CLOSE_CONSUMER",
	17: "PRODUCER_SUCCESS",
	18: "PING",
	19: "PONG",
	20: "REDELIVER_UNACKNOWLEDGED_MESSAGES",
	21: "PARTITIONED_METADATA",
	22: "PARTITIONED_METADATA_RESPONSE",
	23: "LOOKUP",
	24: "LOOKUP_RESPONSE",
	25: "CONSUMER_STATS",
	26: "CONSUMER_STATS_RESPONSE",
	27: "REACHED_END_OF_TOPIC",
	28: "SEEK",
	29: "GET_LAST_MESSAGE_ID",
	30: "GET_LAST_MESSAGE_ID_RESPONSE",
	31: "ACTIVE_CONSUMER_CHANGE",
	32: "GET_TOPICS_OF_NAMESPACE",
	33: "GET_TOPICS_OF_NAMESPACE_RESPONSE",
	34: "GET_SCHEMA",
	35: "GET_SCHEMA_RESPONSE",
	36: "AUTH_CHALLENGE",
	37: "AUTH_RESPONSE",
	38: "ACK_RESPONSE",
	39: "GET_OR_CREATE_SCHEMA",
	40: "GET_OR_CREATE_SCHEMA_RESPONSE",
	50: "NEW_TXN",
	51: "NEW_TXN_RESPONSE",
	52: "ADD_PARTITION_TO_TXN",
	53: "ADD_PARTITION_TO_TXN_RESPONSE",
	54: "ADD_SUBSCRIPTION_TO_TXN",
	55: "ADD_SUBSCRIPTION_TO_TXN_RESPONSE",
	56: "END_TXN",
	57: "END_TXN_RESPONSE",
	58: "END_TXN_ON_PARTITION",
	59: "END_TXN_ON_PARTITION_RESPONSE",
	60: "END_TXN_ON_SUBSCRIPTION",
	61: "END_TXN_ON_SUBSCRIPTION_RESPONSE",
}
View Source
var BaseCommand_Type_value = map[string]int32{
	"CONNECT":                           2,
	"CONNECTED":                         3,
	"SUBSCRIBE":                         4,
	"PRODUCER":                          5,
	"SEND":                              6,
	"SEND_RECEIPT":                      7,
	"SEND_ERROR":                        8,
	"MESSAGE":                           9,
	"ACK":                               10,
	"FLOW":                              11,
	"UNSUBSCRIBE":                       12,
	"SUCCESS":                           13,
	"ERROR":                             14,
	"CLOSE_PRODUCER":                    15,
	"CLOSE_CONSUMER":                    16,
	"PRODUCER_SUCCESS":                  17,
	"PING":                              18,
	"PONG":                              19,
	"REDELIVER_UNACKNOWLEDGED_MESSAGES": 20,
	"PARTITIONED_METADATA":              21,
	"PARTITIONED_METADATA_RESPONSE":     22,
	"LOOKUP":                            23,
	"LOOKUP_RESPONSE":                   24,
	"CONSUMER_STATS":                    25,
	"CONSUMER_STATS_RESPONSE":           26,
	"REACHED_END_OF_TOPIC":              27,
	"SEEK":                              28,
	"GET_LAST_MESSAGE_ID":               29,
	"GET_LAST_MESSAGE_ID_RESPONSE":      30,
	"ACTIVE_CONSUMER_CHANGE":            31,
	"GET_TOPICS_OF_NAMESPACE":           32,
	"GET_TOPICS_OF_NAMESPACE_RESPONSE":  33,
	"GET_SCHEMA":                        34,
	"GET_SCHEMA_RESPONSE":               35,
	"AUTH_CHALLENGE":                    36,
	"AUTH_RESPONSE":                     37,
	"ACK_RESPONSE":                      38,
	"GET_OR_CREATE_SCHEMA":              39,
	"GET_OR_CREATE_SCHEMA_RESPONSE":     40,
	"NEW_TXN":                           50,
	"NEW_TXN_RESPONSE":                  51,
	"ADD_PARTITION_TO_TXN":              52,
	"ADD_PARTITION_TO_TXN_RESPONSE":     53,
	"ADD_SUBSCRIPTION_TO_TXN":           54,
	"ADD_SUBSCRIPTION_TO_TXN_RESPONSE":  55,
	"END_TXN":                           56,
	"END_TXN_RESPONSE":                  57,
	"END_TXN_ON_PARTITION":              58,
	"END_TXN_ON_PARTITION_RESPONSE":     59,
	"END_TXN_ON_SUBSCRIPTION":           60,
	"END_TXN_ON_SUBSCRIPTION_RESPONSE":  61,
}
View Source
var CommandAck_AckType_name = map[int32]string{
	0: "Individual",
	1: "Cumulative",
}
View Source
var CommandAck_AckType_value = map[string]int32{
	"Individual": 0,
	"Cumulative": 1,
}
View Source
var CommandAck_ValidationError_name = map[int32]string{
	0: "UncompressedSizeCorruption",
	1: "DecompressionError",
	2: "ChecksumMismatch",
	3: "BatchDeSerializeError",
	4: "DecryptionError",
}
View Source
var CommandAck_ValidationError_value = map[string]int32{
	"UncompressedSizeCorruption": 0,
	"DecompressionError":         1,
	"ChecksumMismatch":           2,
	"BatchDeSerializeError":      3,
	"DecryptionError":            4,
}
View Source
var CommandGetTopicsOfNamespace_Mode_name = map[int32]string{
	0: "PERSISTENT",
	1: "NON_PERSISTENT",
	2: "ALL",
}
View Source
var CommandGetTopicsOfNamespace_Mode_value = map[string]int32{
	"PERSISTENT":     0,
	"NON_PERSISTENT": 1,
	"ALL":            2,
}
View Source
var CommandLookupTopicResponse_LookupType_name = map[int32]string{
	0: "Redirect",
	1: "Connect",
	2: "Failed",
}
View Source
var CommandLookupTopicResponse_LookupType_value = map[string]int32{
	"Redirect": 0,
	"Connect":  1,
	"Failed":   2,
}
View Source
var CommandPartitionedTopicMetadataResponse_LookupType_name = map[int32]string{
	0: "Success",
	1: "Failed",
}
View Source
var CommandPartitionedTopicMetadataResponse_LookupType_value = map[string]int32{
	"Success": 0,
	"Failed":  1,
}
View Source
var CommandSubscribe_InitialPosition_name = map[int32]string{
	0: "Latest",
	1: "Earliest",
}
View Source
var CommandSubscribe_InitialPosition_value = map[string]int32{
	"Latest":   0,
	"Earliest": 1,
}
View Source
var CommandSubscribe_SubType_name = map[int32]string{
	0: "Exclusive",
	1: "Shared",
	2: "Failover",
	3: "Key_Shared",
}
View Source
var CommandSubscribe_SubType_value = map[string]int32{
	"Exclusive":  0,
	"Shared":     1,
	"Failover":   2,
	"Key_Shared": 3,
}
View Source
var CompressionType_name = map[int32]string{
	0: "NONE",
	1: "LZ4",
	2: "ZLIB",
	3: "ZSTD",
	4: "SNAPPY",
}
View Source
var CompressionType_value = map[string]int32{
	"NONE":   0,
	"LZ4":    1,
	"ZLIB":   2,
	"ZSTD":   3,
	"SNAPPY": 4,
}
View Source
var KeySharedMode_name = map[int32]string{
	0: "AUTO_SPLIT",
	1: "STICKY",
}
View Source
var KeySharedMode_value = map[string]int32{
	"AUTO_SPLIT": 0,
	"STICKY":     1,
}
View Source
var ProtocolVersion_name = map[int32]string{
	0:  "v0",
	1:  "v1",
	2:  "v2",
	3:  "v3",
	4:  "v4",
	5:  "v5",
	6:  "v6",
	7:  "v7",
	8:  "v8",
	9:  "v9",
	10: "v10",
	11: "v11",
	12: "v12",
	13: "v13",
	14: "v14",
	15: "v15",
}
View Source
var ProtocolVersion_value = map[string]int32{
	"v0":  0,
	"v1":  1,
	"v2":  2,
	"v3":  3,
	"v4":  4,
	"v5":  5,
	"v6":  6,
	"v7":  7,
	"v8":  8,
	"v9":  9,
	"v10": 10,
	"v11": 11,
	"v12": 12,
	"v13": 13,
	"v14": 14,
	"v15": 15,
}
View Source
var Schema_Type_name = map[int32]string{
	0:  "None",
	1:  "String",
	2:  "Json",
	3:  "Protobuf",
	4:  "Avro",
	5:  "Bool",
	6:  "Int8",
	7:  "Int16",
	8:  "Int32",
	9:  "Int64",
	10: "Float",
	11: "Double",
	12: "Date",
	13: "Time",
	14: "Timestamp",
	15: "KeyValue",
}
View Source
var Schema_Type_value = map[string]int32{
	"None":      0,
	"String":    1,
	"Json":      2,
	"Protobuf":  3,
	"Avro":      4,
	"Bool":      5,
	"Int8":      6,
	"Int16":     7,
	"Int32":     8,
	"Int64":     9,
	"Float":     10,
	"Double":    11,
	"Date":      12,
	"Time":      13,
	"Timestamp": 14,
	"KeyValue":  15,
}
View Source
var ServerError_name = map[int32]string{
	0:  "UnknownError",
	1:  "MetadataError",
	2:  "PersistenceError",
	3:  "AuthenticationError",
	4:  "AuthorizationError",
	5:  "ConsumerBusy",
	6:  "ServiceNotReady",
	7:  "ProducerBlockedQuotaExceededError",
	8:  "ProducerBlockedQuotaExceededException",
	9:  "ChecksumError",
	10: "UnsupportedVersionError",
	11: "TopicNotFound",
	12: "SubscriptionNotFound",
	13: "ConsumerNotFound",
	14: "TooManyRequests",
	15: "TopicTerminatedError",
	16: "ProducerBusy",
	17: "InvalidTopicName",
	18: "IncompatibleSchema",
	19: "ConsumerAssignError",
	20: "TransactionCoordinatorNotFound",
	21: "InvalidTxnStatus",
}
View Source
var ServerError_value = map[string]int32{
	"UnknownError":                          0,
	"MetadataError":                         1,
	"PersistenceError":                      2,
	"AuthenticationError":                   3,
	"AuthorizationError":                    4,
	"ConsumerBusy":                          5,
	"ServiceNotReady":                       6,
	"ProducerBlockedQuotaExceededError":     7,
	"ProducerBlockedQuotaExceededException": 8,
	"ChecksumError":                         9,
	"UnsupportedVersionError":               10,
	"TopicNotFound":                         11,
	"SubscriptionNotFound":                  12,
	"ConsumerNotFound":                      13,
	"TooManyRequests":                       14,
	"TopicTerminatedError":                  15,
	"ProducerBusy":                          16,
	"InvalidTopicName":                      17,
	"IncompatibleSchema":                    18,
	"ConsumerAssignError":                   19,
	"TransactionCoordinatorNotFound":        20,
	"InvalidTxnStatus":                      21,
}
View Source
var TxnAction_name = map[int32]string{
	0: "COMMIT",
	1: "ABORT",
}
View Source
var TxnAction_value = map[string]int32{
	"COMMIT": 0,
	"ABORT":  1,
}

Functions

This section is empty.

Types

type AuthData

type AuthData struct {
	AuthMethodName       *string  `protobuf:"bytes,1,opt,name=auth_method_name,json=authMethodName" json:"auth_method_name,omitempty"`
	AuthData             []byte   `protobuf:"bytes,2,opt,name=auth_data,json=authData" json:"auth_data,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

To support mutual authentication type, such as Sasl, reuse this command to mutual auth.

func (*AuthData) Descriptor

func (*AuthData) Descriptor() ([]byte, []int)

func (*AuthData) GetAuthData

func (m *AuthData) GetAuthData() []byte

func (*AuthData) GetAuthMethodName

func (m *AuthData) GetAuthMethodName() string

func (*AuthData) Marshal

func (m *AuthData) Marshal() (dAtA []byte, err error)

func (*AuthData) MarshalTo

func (m *AuthData) MarshalTo(dAtA []byte) (int, error)

func (*AuthData) MarshalToSizedBuffer

func (m *AuthData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*AuthData) ProtoMessage

func (*AuthData) ProtoMessage()

func (*AuthData) Reset

func (m *AuthData) Reset()

func (*AuthData) Size

func (m *AuthData) Size() (n int)

func (*AuthData) String

func (m *AuthData) String() string

func (*AuthData) Unmarshal

func (m *AuthData) Unmarshal(dAtA []byte) error

func (*AuthData) XXX_DiscardUnknown

func (m *AuthData) XXX_DiscardUnknown()

func (*AuthData) XXX_Marshal

func (m *AuthData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*AuthData) XXX_Merge

func (m *AuthData) XXX_Merge(src proto.Message)

func (*AuthData) XXX_Size

func (m *AuthData) XXX_Size() int

func (*AuthData) XXX_Unmarshal

func (m *AuthData) XXX_Unmarshal(b []byte) error

type AuthMethod

type AuthMethod int32
const (
	AuthMethod_AuthMethodNone   AuthMethod = 0
	AuthMethod_AuthMethodYcaV1  AuthMethod = 1
	AuthMethod_AuthMethodAthens AuthMethod = 2
)

func (AuthMethod) Enum

func (x AuthMethod) Enum() *AuthMethod

func (AuthMethod) EnumDescriptor

func (AuthMethod) EnumDescriptor() ([]byte, []int)

func (AuthMethod) String

func (x AuthMethod) String() string

func (*AuthMethod) UnmarshalJSON

func (x *AuthMethod) UnmarshalJSON(data []byte) error

type BaseCommand

type BaseCommand struct {
	Type                            *BaseCommand_Type                        `protobuf:"varint,1,req,name=type,enum=pulsar.proto.BaseCommand_Type" json:"type,omitempty"`
	Connect                         *CommandConnect                          `protobuf:"bytes,2,opt,name=connect" json:"connect,omitempty"`
	Connected                       *CommandConnected                        `protobuf:"bytes,3,opt,name=connected" json:"connected,omitempty"`
	Subscribe                       *CommandSubscribe                        `protobuf:"bytes,4,opt,name=subscribe" json:"subscribe,omitempty"`
	Producer                        *CommandProducer                         `protobuf:"bytes,5,opt,name=producer" json:"producer,omitempty"`
	Send                            *CommandSend                             `protobuf:"bytes,6,opt,name=send" json:"send,omitempty"`
	SendReceipt                     *CommandSendReceipt                      `protobuf:"bytes,7,opt,name=send_receipt,json=sendReceipt" json:"send_receipt,omitempty"`
	SendError                       *CommandSendError                        `protobuf:"bytes,8,opt,name=send_error,json=sendError" json:"send_error,omitempty"`
	Message                         *CommandMessage                          `protobuf:"bytes,9,opt,name=message" json:"message,omitempty"`
	Ack                             *CommandAck                              `protobuf:"bytes,10,opt,name=ack" json:"ack,omitempty"`
	Flow                            *CommandFlow                             `protobuf:"bytes,11,opt,name=flow" json:"flow,omitempty"`
	Unsubscribe                     *CommandUnsubscribe                      `protobuf:"bytes,12,opt,name=unsubscribe" json:"unsubscribe,omitempty"`
	Success                         *CommandSuccess                          `protobuf:"bytes,13,opt,name=success" json:"success,omitempty"`
	Error                           *CommandError                            `protobuf:"bytes,14,opt,name=error" json:"error,omitempty"`
	CloseProducer                   *CommandCloseProducer                    `protobuf:"bytes,15,opt,name=close_producer,json=closeProducer" json:"close_producer,omitempty"`
	CloseConsumer                   *CommandCloseConsumer                    `protobuf:"bytes,16,opt,name=close_consumer,json=closeConsumer" json:"close_consumer,omitempty"`
	ProducerSuccess                 *CommandProducerSuccess                  `protobuf:"bytes,17,opt,name=producer_success,json=producerSuccess" json:"producer_success,omitempty"`
	Ping                            *CommandPing                             `protobuf:"bytes,18,opt,name=ping" json:"ping,omitempty"`
	Pong                            *CommandPong                             `protobuf:"bytes,19,opt,name=pong" json:"pong,omitempty"`
	RedeliverUnacknowledgedMessages *CommandRedeliverUnacknowledgedMessages  `protobuf:"bytes,20,opt,name=redeliverUnacknowledgedMessages" json:"redeliverUnacknowledgedMessages,omitempty"`
	PartitionMetadata               *CommandPartitionedTopicMetadata         `protobuf:"bytes,21,opt,name=partitionMetadata" json:"partitionMetadata,omitempty"`
	PartitionMetadataResponse       *CommandPartitionedTopicMetadataResponse `protobuf:"bytes,22,opt,name=partitionMetadataResponse" json:"partitionMetadataResponse,omitempty"`
	LookupTopic                     *CommandLookupTopic                      `protobuf:"bytes,23,opt,name=lookupTopic" json:"lookupTopic,omitempty"`
	LookupTopicResponse             *CommandLookupTopicResponse              `protobuf:"bytes,24,opt,name=lookupTopicResponse" json:"lookupTopicResponse,omitempty"`
	ConsumerStats                   *CommandConsumerStats                    `protobuf:"bytes,25,opt,name=consumerStats" json:"consumerStats,omitempty"`
	ConsumerStatsResponse           *CommandConsumerStatsResponse            `protobuf:"bytes,26,opt,name=consumerStatsResponse" json:"consumerStatsResponse,omitempty"`
	ReachedEndOfTopic               *CommandReachedEndOfTopic                `protobuf:"bytes,27,opt,name=reachedEndOfTopic" json:"reachedEndOfTopic,omitempty"`
	Seek                            *CommandSeek                             `protobuf:"bytes,28,opt,name=seek" json:"seek,omitempty"`
	GetLastMessageId                *CommandGetLastMessageId                 `protobuf:"bytes,29,opt,name=getLastMessageId" json:"getLastMessageId,omitempty"`
	GetLastMessageIdResponse        *CommandGetLastMessageIdResponse         `protobuf:"bytes,30,opt,name=getLastMessageIdResponse" json:"getLastMessageIdResponse,omitempty"`
	ActiveConsumerChange            *CommandActiveConsumerChange             `protobuf:"bytes,31,opt,name=active_consumer_change,json=activeConsumerChange" json:"active_consumer_change,omitempty"`
	GetTopicsOfNamespace            *CommandGetTopicsOfNamespace             `protobuf:"bytes,32,opt,name=getTopicsOfNamespace" json:"getTopicsOfNamespace,omitempty"`
	GetTopicsOfNamespaceResponse    *CommandGetTopicsOfNamespaceResponse     `protobuf:"bytes,33,opt,name=getTopicsOfNamespaceResponse" json:"getTopicsOfNamespaceResponse,omitempty"`
	GetSchema                       *CommandGetSchema                        `protobuf:"bytes,34,opt,name=getSchema" json:"getSchema,omitempty"`
	GetSchemaResponse               *CommandGetSchemaResponse                `protobuf:"bytes,35,opt,name=getSchemaResponse" json:"getSchemaResponse,omitempty"`
	AuthChallenge                   *CommandAuthChallenge                    `protobuf:"bytes,36,opt,name=authChallenge" json:"authChallenge,omitempty"`
	AuthResponse                    *CommandAuthResponse                     `protobuf:"bytes,37,opt,name=authResponse" json:"authResponse,omitempty"`
	AckResponse                     *CommandAckResponse                      `protobuf:"bytes,38,opt,name=ackResponse" json:"ackResponse,omitempty"`
	GetOrCreateSchema               *CommandGetOrCreateSchema                `protobuf:"bytes,39,opt,name=getOrCreateSchema" json:"getOrCreateSchema,omitempty"`
	GetOrCreateSchemaResponse       *CommandGetOrCreateSchemaResponse        `protobuf:"bytes,40,opt,name=getOrCreateSchemaResponse" json:"getOrCreateSchemaResponse,omitempty"`
	// transaction related
	NewTxn                       *CommandNewTxn                       `protobuf:"bytes,50,opt,name=newTxn" json:"newTxn,omitempty"`
	NewTxnResponse               *CommandNewTxnResponse               `protobuf:"bytes,51,opt,name=newTxnResponse" json:"newTxnResponse,omitempty"`
	AddPartitionToTxn            *CommandAddPartitionToTxn            `protobuf:"bytes,52,opt,name=addPartitionToTxn" json:"addPartitionToTxn,omitempty"`
	AddPartitionToTxnResponse    *CommandAddPartitionToTxnResponse    `protobuf:"bytes,53,opt,name=addPartitionToTxnResponse" json:"addPartitionToTxnResponse,omitempty"`
	AddSubscriptionToTxn         *CommandAddSubscriptionToTxn         `protobuf:"bytes,54,opt,name=addSubscriptionToTxn" json:"addSubscriptionToTxn,omitempty"`
	AddSubscriptionToTxnResponse *CommandAddSubscriptionToTxnResponse `protobuf:"bytes,55,opt,name=addSubscriptionToTxnResponse" json:"addSubscriptionToTxnResponse,omitempty"`
	EndTxn                       *CommandEndTxn                       `protobuf:"bytes,56,opt,name=endTxn" json:"endTxn,omitempty"`
	EndTxnResponse               *CommandEndTxnResponse               `protobuf:"bytes,57,opt,name=endTxnResponse" json:"endTxnResponse,omitempty"`
	EndTxnOnPartition            *CommandEndTxnOnPartition            `protobuf:"bytes,58,opt,name=endTxnOnPartition" json:"endTxnOnPartition,omitempty"`
	EndTxnOnPartitionResponse    *CommandEndTxnOnPartitionResponse    `protobuf:"bytes,59,opt,name=endTxnOnPartitionResponse" json:"endTxnOnPartitionResponse,omitempty"`
	EndTxnOnSubscription         *CommandEndTxnOnSubscription         `protobuf:"bytes,60,opt,name=endTxnOnSubscription" json:"endTxnOnSubscription,omitempty"`
	EndTxnOnSubscriptionResponse *CommandEndTxnOnSubscriptionResponse `protobuf:"bytes,61,opt,name=endTxnOnSubscriptionResponse" json:"endTxnOnSubscriptionResponse,omitempty"`
	XXX_NoUnkeyedLiteral         struct{}                             `json:"-"`
	XXX_unrecognized             []byte                               `json:"-"`
	XXX_sizecache                int32                                `json:"-"`
}

func (*BaseCommand) Descriptor

func (*BaseCommand) Descriptor() ([]byte, []int)

func (*BaseCommand) GetAck

func (m *BaseCommand) GetAck() *CommandAck

func (*BaseCommand) GetAckResponse

func (m *BaseCommand) GetAckResponse() *CommandAckResponse

func (*BaseCommand) GetActiveConsumerChange

func (m *BaseCommand) GetActiveConsumerChange() *CommandActiveConsumerChange

func (*BaseCommand) GetAddPartitionToTxn

func (m *BaseCommand) GetAddPartitionToTxn() *CommandAddPartitionToTxn

func (*BaseCommand) GetAddPartitionToTxnResponse

func (m *BaseCommand) GetAddPartitionToTxnResponse() *CommandAddPartitionToTxnResponse

func (*BaseCommand) GetAddSubscriptionToTxn

func (m *BaseCommand) GetAddSubscriptionToTxn() *CommandAddSubscriptionToTxn

func (*BaseCommand) GetAddSubscriptionToTxnResponse

func (m *BaseCommand) GetAddSubscriptionToTxnResponse() *CommandAddSubscriptionToTxnResponse

func (*BaseCommand) GetAuthChallenge

func (m *BaseCommand) GetAuthChallenge() *CommandAuthChallenge

func (*BaseCommand) GetAuthResponse

func (m *BaseCommand) GetAuthResponse() *CommandAuthResponse

func (*BaseCommand) GetCloseConsumer

func (m *BaseCommand) GetCloseConsumer() *CommandCloseConsumer

func (*BaseCommand) GetCloseProducer

func (m *BaseCommand) GetCloseProducer() *CommandCloseProducer

func (*BaseCommand) GetConnect

func (m *BaseCommand) GetConnect() *CommandConnect

func (*BaseCommand) GetConnected

func (m *BaseCommand) GetConnected() *CommandConnected

func (*BaseCommand) GetConsumerStats

func (m *BaseCommand) GetConsumerStats() *CommandConsumerStats

func (*BaseCommand) GetConsumerStatsResponse

func (m *BaseCommand) GetConsumerStatsResponse() *CommandConsumerStatsResponse

func (*BaseCommand) GetEndTxn

func (m *BaseCommand) GetEndTxn() *CommandEndTxn

func (*BaseCommand) GetEndTxnOnPartition

func (m *BaseCommand) GetEndTxnOnPartition() *CommandEndTxnOnPartition

func (*BaseCommand) GetEndTxnOnPartitionResponse

func (m *BaseCommand) GetEndTxnOnPartitionResponse() *CommandEndTxnOnPartitionResponse

func (*BaseCommand) GetEndTxnOnSubscription

func (m *BaseCommand) GetEndTxnOnSubscription() *CommandEndTxnOnSubscription

func (*BaseCommand) GetEndTxnOnSubscriptionResponse

func (m *BaseCommand) GetEndTxnOnSubscriptionResponse() *CommandEndTxnOnSubscriptionResponse

func (*BaseCommand) GetEndTxnResponse

func (m *BaseCommand) GetEndTxnResponse() *CommandEndTxnResponse

func (*BaseCommand) GetError

func (m *BaseCommand) GetError() *CommandError

func (*BaseCommand) GetFlow

func (m *BaseCommand) GetFlow() *CommandFlow

func (*BaseCommand) GetGetLastMessageId

func (m *BaseCommand) GetGetLastMessageId() *CommandGetLastMessageId

func (*BaseCommand) GetGetLastMessageIdResponse

func (m *BaseCommand) GetGetLastMessageIdResponse() *CommandGetLastMessageIdResponse

func (*BaseCommand) GetGetOrCreateSchema

func (m *BaseCommand) GetGetOrCreateSchema() *CommandGetOrCreateSchema

func (*BaseCommand) GetGetOrCreateSchemaResponse

func (m *BaseCommand) GetGetOrCreateSchemaResponse() *CommandGetOrCreateSchemaResponse

func (*BaseCommand) GetGetSchema

func (m *BaseCommand) GetGetSchema() *CommandGetSchema

func (*BaseCommand) GetGetSchemaResponse

func (m *BaseCommand) GetGetSchemaResponse() *CommandGetSchemaResponse

func (*BaseCommand) GetGetTopicsOfNamespace

func (m *BaseCommand) GetGetTopicsOfNamespace() *CommandGetTopicsOfNamespace

func (*BaseCommand) GetGetTopicsOfNamespaceResponse

func (m *BaseCommand) GetGetTopicsOfNamespaceResponse() *CommandGetTopicsOfNamespaceResponse

func (*BaseCommand) GetLookupTopic

func (m *BaseCommand) GetLookupTopic() *CommandLookupTopic

func (*BaseCommand) GetLookupTopicResponse

func (m *BaseCommand) GetLookupTopicResponse() *CommandLookupTopicResponse

func (*BaseCommand) GetMessage

func (m *BaseCommand) GetMessage() *CommandMessage

func (*BaseCommand) GetNewTxn

func (m *BaseCommand) GetNewTxn() *CommandNewTxn

func (*BaseCommand) GetNewTxnResponse

func (m *BaseCommand) GetNewTxnResponse() *CommandNewTxnResponse

func (*BaseCommand) GetPartitionMetadata

func (m *BaseCommand) GetPartitionMetadata() *CommandPartitionedTopicMetadata

func (*BaseCommand) GetPartitionMetadataResponse

func (m *BaseCommand) GetPartitionMetadataResponse() *CommandPartitionedTopicMetadataResponse

func (*BaseCommand) GetPing

func (m *BaseCommand) GetPing() *CommandPing

func (*BaseCommand) GetPong

func (m *BaseCommand) GetPong() *CommandPong

func (*BaseCommand) GetProducer

func (m *BaseCommand) GetProducer() *CommandProducer

func (*BaseCommand) GetProducerSuccess

func (m *BaseCommand) GetProducerSuccess() *CommandProducerSuccess

func (*BaseCommand) GetReachedEndOfTopic

func (m *BaseCommand) GetReachedEndOfTopic() *CommandReachedEndOfTopic

func (*BaseCommand) GetRedeliverUnacknowledgedMessages

func (m *BaseCommand) GetRedeliverUnacknowledgedMessages() *CommandRedeliverUnacknowledgedMessages

func (*BaseCommand) GetSeek

func (m *BaseCommand) GetSeek() *CommandSeek

func (*BaseCommand) GetSend

func (m *BaseCommand) GetSend() *CommandSend

func (*BaseCommand) GetSendError

func (m *BaseCommand) GetSendError() *CommandSendError

func (*BaseCommand) GetSendReceipt

func (m *BaseCommand) GetSendReceipt() *CommandSendReceipt

func (*BaseCommand) GetSubscribe

func (m *BaseCommand) GetSubscribe() *CommandSubscribe

func (*BaseCommand) GetSuccess

func (m *BaseCommand) GetSuccess() *CommandSuccess

func (*BaseCommand) GetType

func (m *BaseCommand) GetType() BaseCommand_Type

func (*BaseCommand) GetUnsubscribe

func (m *BaseCommand) GetUnsubscribe() *CommandUnsubscribe

func (*BaseCommand) Marshal

func (m *BaseCommand) Marshal() (dAtA []byte, err error)

func (*BaseCommand) MarshalTo

func (m *BaseCommand) MarshalTo(dAtA []byte) (int, error)

func (*BaseCommand) MarshalToSizedBuffer

func (m *BaseCommand) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*BaseCommand) ProtoMessage

func (*BaseCommand) ProtoMessage()

func (*BaseCommand) Reset

func (m *BaseCommand) Reset()

func (*BaseCommand) Size

func (m *BaseCommand) Size() (n int)

func (*BaseCommand) String

func (m *BaseCommand) String() string

func (*BaseCommand) Unmarshal

func (m *BaseCommand) Unmarshal(dAtA []byte) error

func (*BaseCommand) XXX_DiscardUnknown

func (m *BaseCommand) XXX_DiscardUnknown()

func (*BaseCommand) XXX_Marshal

func (m *BaseCommand) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*BaseCommand) XXX_Merge

func (m *BaseCommand) XXX_Merge(src proto.Message)

func (*BaseCommand) XXX_Size

func (m *BaseCommand) XXX_Size() int

func (*BaseCommand) XXX_Unmarshal

func (m *BaseCommand) XXX_Unmarshal(b []byte) error

type BaseCommand_Type

type BaseCommand_Type int32
const (
	BaseCommand_CONNECT                           BaseCommand_Type = 2
	BaseCommand_CONNECTED                         BaseCommand_Type = 3
	BaseCommand_SUBSCRIBE                         BaseCommand_Type = 4
	BaseCommand_PRODUCER                          BaseCommand_Type = 5
	BaseCommand_SEND                              BaseCommand_Type = 6
	BaseCommand_SEND_RECEIPT                      BaseCommand_Type = 7
	BaseCommand_SEND_ERROR                        BaseCommand_Type = 8
	BaseCommand_MESSAGE                           BaseCommand_Type = 9
	BaseCommand_ACK                               BaseCommand_Type = 10
	BaseCommand_FLOW                              BaseCommand_Type = 11
	BaseCommand_UNSUBSCRIBE                       BaseCommand_Type = 12
	BaseCommand_SUCCESS                           BaseCommand_Type = 13
	BaseCommand_ERROR                             BaseCommand_Type = 14
	BaseCommand_CLOSE_PRODUCER                    BaseCommand_Type = 15
	BaseCommand_CLOSE_CONSUMER                    BaseCommand_Type = 16
	BaseCommand_PRODUCER_SUCCESS                  BaseCommand_Type = 17
	BaseCommand_PING                              BaseCommand_Type = 18
	BaseCommand_PONG                              BaseCommand_Type = 19
	BaseCommand_REDELIVER_UNACKNOWLEDGED_MESSAGES BaseCommand_Type = 20
	BaseCommand_PARTITIONED_METADATA              BaseCommand_Type = 21
	BaseCommand_PARTITIONED_METADATA_RESPONSE     BaseCommand_Type = 22
	BaseCommand_LOOKUP                            BaseCommand_Type = 23
	BaseCommand_LOOKUP_RESPONSE                   BaseCommand_Type = 24
	BaseCommand_CONSUMER_STATS                    BaseCommand_Type = 25
	BaseCommand_CONSUMER_STATS_RESPONSE           BaseCommand_Type = 26
	BaseCommand_REACHED_END_OF_TOPIC              BaseCommand_Type = 27
	BaseCommand_SEEK                              BaseCommand_Type = 28
	BaseCommand_GET_LAST_MESSAGE_ID               BaseCommand_Type = 29
	BaseCommand_GET_LAST_MESSAGE_ID_RESPONSE      BaseCommand_Type = 30
	BaseCommand_ACTIVE_CONSUMER_CHANGE            BaseCommand_Type = 31
	BaseCommand_GET_TOPICS_OF_NAMESPACE           BaseCommand_Type = 32
	BaseCommand_GET_TOPICS_OF_NAMESPACE_RESPONSE  BaseCommand_Type = 33
	BaseCommand_GET_SCHEMA                        BaseCommand_Type = 34
	BaseCommand_GET_SCHEMA_RESPONSE               BaseCommand_Type = 35
	BaseCommand_AUTH_CHALLENGE                    BaseCommand_Type = 36
	BaseCommand_AUTH_RESPONSE                     BaseCommand_Type = 37
	BaseCommand_ACK_RESPONSE                      BaseCommand_Type = 38
	BaseCommand_GET_OR_CREATE_SCHEMA              BaseCommand_Type = 39
	BaseCommand_GET_OR_CREATE_SCHEMA_RESPONSE     BaseCommand_Type = 40
	// transaction related
	BaseCommand_NEW_TXN                          BaseCommand_Type = 50
	BaseCommand_NEW_TXN_RESPONSE                 BaseCommand_Type = 51
	BaseCommand_ADD_PARTITION_TO_TXN             BaseCommand_Type = 52
	BaseCommand_ADD_PARTITION_TO_TXN_RESPONSE    BaseCommand_Type = 53
	BaseCommand_ADD_SUBSCRIPTION_TO_TXN          BaseCommand_Type = 54
	BaseCommand_ADD_SUBSCRIPTION_TO_TXN_RESPONSE BaseCommand_Type = 55
	BaseCommand_END_TXN                          BaseCommand_Type = 56
	BaseCommand_END_TXN_RESPONSE                 BaseCommand_Type = 57
	BaseCommand_END_TXN_ON_PARTITION             BaseCommand_Type = 58
	BaseCommand_END_TXN_ON_PARTITION_RESPONSE    BaseCommand_Type = 59
	BaseCommand_END_TXN_ON_SUBSCRIPTION          BaseCommand_Type = 60
	BaseCommand_END_TXN_ON_SUBSCRIPTION_RESPONSE BaseCommand_Type = 61
)

func (BaseCommand_Type) Enum

func (BaseCommand_Type) EnumDescriptor

func (BaseCommand_Type) EnumDescriptor() ([]byte, []int)

func (BaseCommand_Type) String

func (x BaseCommand_Type) String() string

func (*BaseCommand_Type) UnmarshalJSON

func (x *BaseCommand_Type) UnmarshalJSON(data []byte) error

type CommandAck

type CommandAck struct {
	ConsumerId *uint64             `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	AckType    *CommandAck_AckType `protobuf:"varint,2,req,name=ack_type,json=ackType,enum=pulsar.proto.CommandAck_AckType" json:"ack_type,omitempty"`
	// In case of individual acks, the client can pass a list of message ids
	MessageId            []*MessageIdData            `protobuf:"bytes,3,rep,name=message_id,json=messageId" json:"message_id,omitempty"`
	ValidationError      *CommandAck_ValidationError `` /* 145-byte string literal not displayed */
	Properties           []*KeyLongValue             `protobuf:"bytes,5,rep,name=properties" json:"properties,omitempty"`
	TxnidLeastBits       *uint64                     `protobuf:"varint,6,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64                     `protobuf:"varint,7,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	XXX_NoUnkeyedLiteral struct{}                    `json:"-"`
	XXX_unrecognized     []byte                      `json:"-"`
	XXX_sizecache        int32                       `json:"-"`
}

func (*CommandAck) Descriptor

func (*CommandAck) Descriptor() ([]byte, []int)

func (*CommandAck) GetAckType

func (m *CommandAck) GetAckType() CommandAck_AckType

func (*CommandAck) GetConsumerId

func (m *CommandAck) GetConsumerId() uint64

func (*CommandAck) GetMessageId

func (m *CommandAck) GetMessageId() []*MessageIdData

func (*CommandAck) GetProperties

func (m *CommandAck) GetProperties() []*KeyLongValue

func (*CommandAck) GetTxnidLeastBits

func (m *CommandAck) GetTxnidLeastBits() uint64

func (*CommandAck) GetTxnidMostBits

func (m *CommandAck) GetTxnidMostBits() uint64

func (*CommandAck) GetValidationError

func (m *CommandAck) GetValidationError() CommandAck_ValidationError

func (*CommandAck) Marshal

func (m *CommandAck) Marshal() (dAtA []byte, err error)

func (*CommandAck) MarshalTo

func (m *CommandAck) MarshalTo(dAtA []byte) (int, error)

func (*CommandAck) MarshalToSizedBuffer

func (m *CommandAck) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAck) ProtoMessage

func (*CommandAck) ProtoMessage()

func (*CommandAck) Reset

func (m *CommandAck) Reset()

func (*CommandAck) Size

func (m *CommandAck) Size() (n int)

func (*CommandAck) String

func (m *CommandAck) String() string

func (*CommandAck) Unmarshal

func (m *CommandAck) Unmarshal(dAtA []byte) error

func (*CommandAck) XXX_DiscardUnknown

func (m *CommandAck) XXX_DiscardUnknown()

func (*CommandAck) XXX_Marshal

func (m *CommandAck) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAck) XXX_Merge

func (m *CommandAck) XXX_Merge(src proto.Message)

func (*CommandAck) XXX_Size

func (m *CommandAck) XXX_Size() int

func (*CommandAck) XXX_Unmarshal

func (m *CommandAck) XXX_Unmarshal(b []byte) error

type CommandAckResponse

type CommandAckResponse struct {
	ConsumerId           *uint64      `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandAckResponse) Descriptor

func (*CommandAckResponse) Descriptor() ([]byte, []int)

func (*CommandAckResponse) GetConsumerId

func (m *CommandAckResponse) GetConsumerId() uint64

func (*CommandAckResponse) GetError

func (m *CommandAckResponse) GetError() ServerError

func (*CommandAckResponse) GetMessage

func (m *CommandAckResponse) GetMessage() string

func (*CommandAckResponse) GetTxnidLeastBits

func (m *CommandAckResponse) GetTxnidLeastBits() uint64

func (*CommandAckResponse) GetTxnidMostBits

func (m *CommandAckResponse) GetTxnidMostBits() uint64

func (*CommandAckResponse) Marshal

func (m *CommandAckResponse) Marshal() (dAtA []byte, err error)

func (*CommandAckResponse) MarshalTo

func (m *CommandAckResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandAckResponse) MarshalToSizedBuffer

func (m *CommandAckResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAckResponse) ProtoMessage

func (*CommandAckResponse) ProtoMessage()

func (*CommandAckResponse) Reset

func (m *CommandAckResponse) Reset()

func (*CommandAckResponse) Size

func (m *CommandAckResponse) Size() (n int)

func (*CommandAckResponse) String

func (m *CommandAckResponse) String() string

func (*CommandAckResponse) Unmarshal

func (m *CommandAckResponse) Unmarshal(dAtA []byte) error

func (*CommandAckResponse) XXX_DiscardUnknown

func (m *CommandAckResponse) XXX_DiscardUnknown()

func (*CommandAckResponse) XXX_Marshal

func (m *CommandAckResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAckResponse) XXX_Merge

func (m *CommandAckResponse) XXX_Merge(src proto.Message)

func (*CommandAckResponse) XXX_Size

func (m *CommandAckResponse) XXX_Size() int

func (*CommandAckResponse) XXX_Unmarshal

func (m *CommandAckResponse) XXX_Unmarshal(b []byte) error

type CommandAck_AckType

type CommandAck_AckType int32
const (
	CommandAck_Individual CommandAck_AckType = 0
	CommandAck_Cumulative CommandAck_AckType = 1
)

func (CommandAck_AckType) Enum

func (CommandAck_AckType) EnumDescriptor

func (CommandAck_AckType) EnumDescriptor() ([]byte, []int)

func (CommandAck_AckType) String

func (x CommandAck_AckType) String() string

func (*CommandAck_AckType) UnmarshalJSON

func (x *CommandAck_AckType) UnmarshalJSON(data []byte) error

type CommandAck_ValidationError

type CommandAck_ValidationError int32

Acks can contain a flag to indicate the consumer received an invalid message that got discarded before being passed on to the application.

const (
	CommandAck_UncompressedSizeCorruption CommandAck_ValidationError = 0
	CommandAck_DecompressionError         CommandAck_ValidationError = 1
	CommandAck_ChecksumMismatch           CommandAck_ValidationError = 2
	CommandAck_BatchDeSerializeError      CommandAck_ValidationError = 3
	CommandAck_DecryptionError            CommandAck_ValidationError = 4
)

func (CommandAck_ValidationError) Enum

func (CommandAck_ValidationError) EnumDescriptor

func (CommandAck_ValidationError) EnumDescriptor() ([]byte, []int)

func (CommandAck_ValidationError) String

func (*CommandAck_ValidationError) UnmarshalJSON

func (x *CommandAck_ValidationError) UnmarshalJSON(data []byte) error

type CommandActiveConsumerChange

type CommandActiveConsumerChange struct {
	ConsumerId           *uint64  `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	IsActive             *bool    `protobuf:"varint,2,opt,name=is_active,json=isActive,def=0" json:"is_active,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

changes on active consumer

func (*CommandActiveConsumerChange) Descriptor

func (*CommandActiveConsumerChange) Descriptor() ([]byte, []int)

func (*CommandActiveConsumerChange) GetConsumerId

func (m *CommandActiveConsumerChange) GetConsumerId() uint64

func (*CommandActiveConsumerChange) GetIsActive

func (m *CommandActiveConsumerChange) GetIsActive() bool

func (*CommandActiveConsumerChange) Marshal

func (m *CommandActiveConsumerChange) Marshal() (dAtA []byte, err error)

func (*CommandActiveConsumerChange) MarshalTo

func (m *CommandActiveConsumerChange) MarshalTo(dAtA []byte) (int, error)

func (*CommandActiveConsumerChange) MarshalToSizedBuffer

func (m *CommandActiveConsumerChange) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandActiveConsumerChange) ProtoMessage

func (*CommandActiveConsumerChange) ProtoMessage()

func (*CommandActiveConsumerChange) Reset

func (m *CommandActiveConsumerChange) Reset()

func (*CommandActiveConsumerChange) Size

func (m *CommandActiveConsumerChange) Size() (n int)

func (*CommandActiveConsumerChange) String

func (m *CommandActiveConsumerChange) String() string

func (*CommandActiveConsumerChange) Unmarshal

func (m *CommandActiveConsumerChange) Unmarshal(dAtA []byte) error

func (*CommandActiveConsumerChange) XXX_DiscardUnknown

func (m *CommandActiveConsumerChange) XXX_DiscardUnknown()

func (*CommandActiveConsumerChange) XXX_Marshal

func (m *CommandActiveConsumerChange) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandActiveConsumerChange) XXX_Merge

func (m *CommandActiveConsumerChange) XXX_Merge(src proto.Message)

func (*CommandActiveConsumerChange) XXX_Size

func (m *CommandActiveConsumerChange) XXX_Size() int

func (*CommandActiveConsumerChange) XXX_Unmarshal

func (m *CommandActiveConsumerChange) XXX_Unmarshal(b []byte) error

type CommandAddPartitionToTxn

type CommandAddPartitionToTxn struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64  `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64  `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Partitions           []string `protobuf:"bytes,4,rep,name=partitions" json:"partitions,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandAddPartitionToTxn) Descriptor

func (*CommandAddPartitionToTxn) Descriptor() ([]byte, []int)

func (*CommandAddPartitionToTxn) GetPartitions

func (m *CommandAddPartitionToTxn) GetPartitions() []string

func (*CommandAddPartitionToTxn) GetRequestId

func (m *CommandAddPartitionToTxn) GetRequestId() uint64

func (*CommandAddPartitionToTxn) GetTxnidLeastBits

func (m *CommandAddPartitionToTxn) GetTxnidLeastBits() uint64

func (*CommandAddPartitionToTxn) GetTxnidMostBits

func (m *CommandAddPartitionToTxn) GetTxnidMostBits() uint64

func (*CommandAddPartitionToTxn) Marshal

func (m *CommandAddPartitionToTxn) Marshal() (dAtA []byte, err error)

func (*CommandAddPartitionToTxn) MarshalTo

func (m *CommandAddPartitionToTxn) MarshalTo(dAtA []byte) (int, error)

func (*CommandAddPartitionToTxn) MarshalToSizedBuffer

func (m *CommandAddPartitionToTxn) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAddPartitionToTxn) ProtoMessage

func (*CommandAddPartitionToTxn) ProtoMessage()

func (*CommandAddPartitionToTxn) Reset

func (m *CommandAddPartitionToTxn) Reset()

func (*CommandAddPartitionToTxn) Size

func (m *CommandAddPartitionToTxn) Size() (n int)

func (*CommandAddPartitionToTxn) String

func (m *CommandAddPartitionToTxn) String() string

func (*CommandAddPartitionToTxn) Unmarshal

func (m *CommandAddPartitionToTxn) Unmarshal(dAtA []byte) error

func (*CommandAddPartitionToTxn) XXX_DiscardUnknown

func (m *CommandAddPartitionToTxn) XXX_DiscardUnknown()

func (*CommandAddPartitionToTxn) XXX_Marshal

func (m *CommandAddPartitionToTxn) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAddPartitionToTxn) XXX_Merge

func (m *CommandAddPartitionToTxn) XXX_Merge(src proto.Message)

func (*CommandAddPartitionToTxn) XXX_Size

func (m *CommandAddPartitionToTxn) XXX_Size() int

func (*CommandAddPartitionToTxn) XXX_Unmarshal

func (m *CommandAddPartitionToTxn) XXX_Unmarshal(b []byte) error

type CommandAddPartitionToTxnResponse

type CommandAddPartitionToTxnResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandAddPartitionToTxnResponse) Descriptor

func (*CommandAddPartitionToTxnResponse) Descriptor() ([]byte, []int)

func (*CommandAddPartitionToTxnResponse) GetError

func (*CommandAddPartitionToTxnResponse) GetMessage

func (m *CommandAddPartitionToTxnResponse) GetMessage() string

func (*CommandAddPartitionToTxnResponse) GetRequestId

func (m *CommandAddPartitionToTxnResponse) GetRequestId() uint64

func (*CommandAddPartitionToTxnResponse) GetTxnidLeastBits

func (m *CommandAddPartitionToTxnResponse) GetTxnidLeastBits() uint64

func (*CommandAddPartitionToTxnResponse) GetTxnidMostBits

func (m *CommandAddPartitionToTxnResponse) GetTxnidMostBits() uint64

func (*CommandAddPartitionToTxnResponse) Marshal

func (m *CommandAddPartitionToTxnResponse) Marshal() (dAtA []byte, err error)

func (*CommandAddPartitionToTxnResponse) MarshalTo

func (m *CommandAddPartitionToTxnResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandAddPartitionToTxnResponse) MarshalToSizedBuffer

func (m *CommandAddPartitionToTxnResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAddPartitionToTxnResponse) ProtoMessage

func (*CommandAddPartitionToTxnResponse) ProtoMessage()

func (*CommandAddPartitionToTxnResponse) Reset

func (*CommandAddPartitionToTxnResponse) Size

func (m *CommandAddPartitionToTxnResponse) Size() (n int)

func (*CommandAddPartitionToTxnResponse) String

func (*CommandAddPartitionToTxnResponse) Unmarshal

func (m *CommandAddPartitionToTxnResponse) Unmarshal(dAtA []byte) error

func (*CommandAddPartitionToTxnResponse) XXX_DiscardUnknown

func (m *CommandAddPartitionToTxnResponse) XXX_DiscardUnknown()

func (*CommandAddPartitionToTxnResponse) XXX_Marshal

func (m *CommandAddPartitionToTxnResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAddPartitionToTxnResponse) XXX_Merge

func (*CommandAddPartitionToTxnResponse) XXX_Size

func (m *CommandAddPartitionToTxnResponse) XXX_Size() int

func (*CommandAddPartitionToTxnResponse) XXX_Unmarshal

func (m *CommandAddPartitionToTxnResponse) XXX_Unmarshal(b []byte) error

type CommandAddSubscriptionToTxn

type CommandAddSubscriptionToTxn struct {
	RequestId            *uint64         `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64         `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64         `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Subscription         []*Subscription `protobuf:"bytes,4,rep,name=subscription" json:"subscription,omitempty"`
	XXX_NoUnkeyedLiteral struct{}        `json:"-"`
	XXX_unrecognized     []byte          `json:"-"`
	XXX_sizecache        int32           `json:"-"`
}

func (*CommandAddSubscriptionToTxn) Descriptor

func (*CommandAddSubscriptionToTxn) Descriptor() ([]byte, []int)

func (*CommandAddSubscriptionToTxn) GetRequestId

func (m *CommandAddSubscriptionToTxn) GetRequestId() uint64

func (*CommandAddSubscriptionToTxn) GetSubscription

func (m *CommandAddSubscriptionToTxn) GetSubscription() []*Subscription

func (*CommandAddSubscriptionToTxn) GetTxnidLeastBits

func (m *CommandAddSubscriptionToTxn) GetTxnidLeastBits() uint64

func (*CommandAddSubscriptionToTxn) GetTxnidMostBits

func (m *CommandAddSubscriptionToTxn) GetTxnidMostBits() uint64

func (*CommandAddSubscriptionToTxn) Marshal

func (m *CommandAddSubscriptionToTxn) Marshal() (dAtA []byte, err error)

func (*CommandAddSubscriptionToTxn) MarshalTo

func (m *CommandAddSubscriptionToTxn) MarshalTo(dAtA []byte) (int, error)

func (*CommandAddSubscriptionToTxn) MarshalToSizedBuffer

func (m *CommandAddSubscriptionToTxn) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAddSubscriptionToTxn) ProtoMessage

func (*CommandAddSubscriptionToTxn) ProtoMessage()

func (*CommandAddSubscriptionToTxn) Reset

func (m *CommandAddSubscriptionToTxn) Reset()

func (*CommandAddSubscriptionToTxn) Size

func (m *CommandAddSubscriptionToTxn) Size() (n int)

func (*CommandAddSubscriptionToTxn) String

func (m *CommandAddSubscriptionToTxn) String() string

func (*CommandAddSubscriptionToTxn) Unmarshal

func (m *CommandAddSubscriptionToTxn) Unmarshal(dAtA []byte) error

func (*CommandAddSubscriptionToTxn) XXX_DiscardUnknown

func (m *CommandAddSubscriptionToTxn) XXX_DiscardUnknown()

func (*CommandAddSubscriptionToTxn) XXX_Marshal

func (m *CommandAddSubscriptionToTxn) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAddSubscriptionToTxn) XXX_Merge

func (m *CommandAddSubscriptionToTxn) XXX_Merge(src proto.Message)

func (*CommandAddSubscriptionToTxn) XXX_Size

func (m *CommandAddSubscriptionToTxn) XXX_Size() int

func (*CommandAddSubscriptionToTxn) XXX_Unmarshal

func (m *CommandAddSubscriptionToTxn) XXX_Unmarshal(b []byte) error

type CommandAddSubscriptionToTxnResponse

type CommandAddSubscriptionToTxnResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandAddSubscriptionToTxnResponse) Descriptor

func (*CommandAddSubscriptionToTxnResponse) Descriptor() ([]byte, []int)

func (*CommandAddSubscriptionToTxnResponse) GetError

func (*CommandAddSubscriptionToTxnResponse) GetMessage

func (*CommandAddSubscriptionToTxnResponse) GetRequestId

func (m *CommandAddSubscriptionToTxnResponse) GetRequestId() uint64

func (*CommandAddSubscriptionToTxnResponse) GetTxnidLeastBits

func (m *CommandAddSubscriptionToTxnResponse) GetTxnidLeastBits() uint64

func (*CommandAddSubscriptionToTxnResponse) GetTxnidMostBits

func (m *CommandAddSubscriptionToTxnResponse) GetTxnidMostBits() uint64

func (*CommandAddSubscriptionToTxnResponse) Marshal

func (m *CommandAddSubscriptionToTxnResponse) Marshal() (dAtA []byte, err error)

func (*CommandAddSubscriptionToTxnResponse) MarshalTo

func (m *CommandAddSubscriptionToTxnResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandAddSubscriptionToTxnResponse) MarshalToSizedBuffer

func (m *CommandAddSubscriptionToTxnResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAddSubscriptionToTxnResponse) ProtoMessage

func (*CommandAddSubscriptionToTxnResponse) ProtoMessage()

func (*CommandAddSubscriptionToTxnResponse) Reset

func (*CommandAddSubscriptionToTxnResponse) Size

func (*CommandAddSubscriptionToTxnResponse) String

func (*CommandAddSubscriptionToTxnResponse) Unmarshal

func (m *CommandAddSubscriptionToTxnResponse) Unmarshal(dAtA []byte) error

func (*CommandAddSubscriptionToTxnResponse) XXX_DiscardUnknown

func (m *CommandAddSubscriptionToTxnResponse) XXX_DiscardUnknown()

func (*CommandAddSubscriptionToTxnResponse) XXX_Marshal

func (m *CommandAddSubscriptionToTxnResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAddSubscriptionToTxnResponse) XXX_Merge

func (*CommandAddSubscriptionToTxnResponse) XXX_Size

func (*CommandAddSubscriptionToTxnResponse) XXX_Unmarshal

func (m *CommandAddSubscriptionToTxnResponse) XXX_Unmarshal(b []byte) error

type CommandAuthChallenge

type CommandAuthChallenge struct {
	ServerVersion        *string   `protobuf:"bytes,1,opt,name=server_version,json=serverVersion" json:"server_version,omitempty"`
	Challenge            *AuthData `protobuf:"bytes,2,opt,name=challenge" json:"challenge,omitempty"`
	ProtocolVersion      *int32    `protobuf:"varint,3,opt,name=protocol_version,json=protocolVersion,def=0" json:"protocol_version,omitempty"`
	XXX_NoUnkeyedLiteral struct{}  `json:"-"`
	XXX_unrecognized     []byte    `json:"-"`
	XXX_sizecache        int32     `json:"-"`
}

func (*CommandAuthChallenge) Descriptor

func (*CommandAuthChallenge) Descriptor() ([]byte, []int)

func (*CommandAuthChallenge) GetChallenge

func (m *CommandAuthChallenge) GetChallenge() *AuthData

func (*CommandAuthChallenge) GetProtocolVersion

func (m *CommandAuthChallenge) GetProtocolVersion() int32

func (*CommandAuthChallenge) GetServerVersion

func (m *CommandAuthChallenge) GetServerVersion() string

func (*CommandAuthChallenge) Marshal

func (m *CommandAuthChallenge) Marshal() (dAtA []byte, err error)

func (*CommandAuthChallenge) MarshalTo

func (m *CommandAuthChallenge) MarshalTo(dAtA []byte) (int, error)

func (*CommandAuthChallenge) MarshalToSizedBuffer

func (m *CommandAuthChallenge) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAuthChallenge) ProtoMessage

func (*CommandAuthChallenge) ProtoMessage()

func (*CommandAuthChallenge) Reset

func (m *CommandAuthChallenge) Reset()

func (*CommandAuthChallenge) Size

func (m *CommandAuthChallenge) Size() (n int)

func (*CommandAuthChallenge) String

func (m *CommandAuthChallenge) String() string

func (*CommandAuthChallenge) Unmarshal

func (m *CommandAuthChallenge) Unmarshal(dAtA []byte) error

func (*CommandAuthChallenge) XXX_DiscardUnknown

func (m *CommandAuthChallenge) XXX_DiscardUnknown()

func (*CommandAuthChallenge) XXX_Marshal

func (m *CommandAuthChallenge) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAuthChallenge) XXX_Merge

func (m *CommandAuthChallenge) XXX_Merge(src proto.Message)

func (*CommandAuthChallenge) XXX_Size

func (m *CommandAuthChallenge) XXX_Size() int

func (*CommandAuthChallenge) XXX_Unmarshal

func (m *CommandAuthChallenge) XXX_Unmarshal(b []byte) error

type CommandAuthResponse

type CommandAuthResponse struct {
	ClientVersion        *string   `protobuf:"bytes,1,opt,name=client_version,json=clientVersion" json:"client_version,omitempty"`
	Response             *AuthData `protobuf:"bytes,2,opt,name=response" json:"response,omitempty"`
	ProtocolVersion      *int32    `protobuf:"varint,3,opt,name=protocol_version,json=protocolVersion,def=0" json:"protocol_version,omitempty"`
	XXX_NoUnkeyedLiteral struct{}  `json:"-"`
	XXX_unrecognized     []byte    `json:"-"`
	XXX_sizecache        int32     `json:"-"`
}

func (*CommandAuthResponse) Descriptor

func (*CommandAuthResponse) Descriptor() ([]byte, []int)

func (*CommandAuthResponse) GetClientVersion

func (m *CommandAuthResponse) GetClientVersion() string

func (*CommandAuthResponse) GetProtocolVersion

func (m *CommandAuthResponse) GetProtocolVersion() int32

func (*CommandAuthResponse) GetResponse

func (m *CommandAuthResponse) GetResponse() *AuthData

func (*CommandAuthResponse) Marshal

func (m *CommandAuthResponse) Marshal() (dAtA []byte, err error)

func (*CommandAuthResponse) MarshalTo

func (m *CommandAuthResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandAuthResponse) MarshalToSizedBuffer

func (m *CommandAuthResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandAuthResponse) ProtoMessage

func (*CommandAuthResponse) ProtoMessage()

func (*CommandAuthResponse) Reset

func (m *CommandAuthResponse) Reset()

func (*CommandAuthResponse) Size

func (m *CommandAuthResponse) Size() (n int)

func (*CommandAuthResponse) String

func (m *CommandAuthResponse) String() string

func (*CommandAuthResponse) Unmarshal

func (m *CommandAuthResponse) Unmarshal(dAtA []byte) error

func (*CommandAuthResponse) XXX_DiscardUnknown

func (m *CommandAuthResponse) XXX_DiscardUnknown()

func (*CommandAuthResponse) XXX_Marshal

func (m *CommandAuthResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandAuthResponse) XXX_Merge

func (m *CommandAuthResponse) XXX_Merge(src proto.Message)

func (*CommandAuthResponse) XXX_Size

func (m *CommandAuthResponse) XXX_Size() int

func (*CommandAuthResponse) XXX_Unmarshal

func (m *CommandAuthResponse) XXX_Unmarshal(b []byte) error

type CommandCloseConsumer

type CommandCloseConsumer struct {
	ConsumerId           *uint64  `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	RequestId            *uint64  `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandCloseConsumer) Descriptor

func (*CommandCloseConsumer) Descriptor() ([]byte, []int)

func (*CommandCloseConsumer) GetConsumerId

func (m *CommandCloseConsumer) GetConsumerId() uint64

func (*CommandCloseConsumer) GetRequestId

func (m *CommandCloseConsumer) GetRequestId() uint64

func (*CommandCloseConsumer) Marshal

func (m *CommandCloseConsumer) Marshal() (dAtA []byte, err error)

func (*CommandCloseConsumer) MarshalTo

func (m *CommandCloseConsumer) MarshalTo(dAtA []byte) (int, error)

func (*CommandCloseConsumer) MarshalToSizedBuffer

func (m *CommandCloseConsumer) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandCloseConsumer) ProtoMessage

func (*CommandCloseConsumer) ProtoMessage()

func (*CommandCloseConsumer) Reset

func (m *CommandCloseConsumer) Reset()

func (*CommandCloseConsumer) Size

func (m *CommandCloseConsumer) Size() (n int)

func (*CommandCloseConsumer) String

func (m *CommandCloseConsumer) String() string

func (*CommandCloseConsumer) Unmarshal

func (m *CommandCloseConsumer) Unmarshal(dAtA []byte) error

func (*CommandCloseConsumer) XXX_DiscardUnknown

func (m *CommandCloseConsumer) XXX_DiscardUnknown()

func (*CommandCloseConsumer) XXX_Marshal

func (m *CommandCloseConsumer) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandCloseConsumer) XXX_Merge

func (m *CommandCloseConsumer) XXX_Merge(src proto.Message)

func (*CommandCloseConsumer) XXX_Size

func (m *CommandCloseConsumer) XXX_Size() int

func (*CommandCloseConsumer) XXX_Unmarshal

func (m *CommandCloseConsumer) XXX_Unmarshal(b []byte) error

type CommandCloseProducer

type CommandCloseProducer struct {
	ProducerId           *uint64  `protobuf:"varint,1,req,name=producer_id,json=producerId" json:"producer_id,omitempty"`
	RequestId            *uint64  `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandCloseProducer) Descriptor

func (*CommandCloseProducer) Descriptor() ([]byte, []int)

func (*CommandCloseProducer) GetProducerId

func (m *CommandCloseProducer) GetProducerId() uint64

func (*CommandCloseProducer) GetRequestId

func (m *CommandCloseProducer) GetRequestId() uint64

func (*CommandCloseProducer) Marshal

func (m *CommandCloseProducer) Marshal() (dAtA []byte, err error)

func (*CommandCloseProducer) MarshalTo

func (m *CommandCloseProducer) MarshalTo(dAtA []byte) (int, error)

func (*CommandCloseProducer) MarshalToSizedBuffer

func (m *CommandCloseProducer) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandCloseProducer) ProtoMessage

func (*CommandCloseProducer) ProtoMessage()

func (*CommandCloseProducer) Reset

func (m *CommandCloseProducer) Reset()

func (*CommandCloseProducer) Size

func (m *CommandCloseProducer) Size() (n int)

func (*CommandCloseProducer) String

func (m *CommandCloseProducer) String() string

func (*CommandCloseProducer) Unmarshal

func (m *CommandCloseProducer) Unmarshal(dAtA []byte) error

func (*CommandCloseProducer) XXX_DiscardUnknown

func (m *CommandCloseProducer) XXX_DiscardUnknown()

func (*CommandCloseProducer) XXX_Marshal

func (m *CommandCloseProducer) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandCloseProducer) XXX_Merge

func (m *CommandCloseProducer) XXX_Merge(src proto.Message)

func (*CommandCloseProducer) XXX_Size

func (m *CommandCloseProducer) XXX_Size() int

func (*CommandCloseProducer) XXX_Unmarshal

func (m *CommandCloseProducer) XXX_Unmarshal(b []byte) error

type CommandConnect

type CommandConnect struct {
	ClientVersion   *string     `protobuf:"bytes,1,req,name=client_version,json=clientVersion" json:"client_version,omitempty"`
	AuthMethod      *AuthMethod `protobuf:"varint,2,opt,name=auth_method,json=authMethod,enum=pulsar.proto.AuthMethod" json:"auth_method,omitempty"`
	AuthMethodName  *string     `protobuf:"bytes,5,opt,name=auth_method_name,json=authMethodName" json:"auth_method_name,omitempty"`
	AuthData        []byte      `protobuf:"bytes,3,opt,name=auth_data,json=authData" json:"auth_data,omitempty"`
	ProtocolVersion *int32      `protobuf:"varint,4,opt,name=protocol_version,json=protocolVersion,def=0" json:"protocol_version,omitempty"`
	// Client can ask to be proxyied to a specific broker
	// This is only honored by a Pulsar proxy
	ProxyToBrokerUrl *string `protobuf:"bytes,6,opt,name=proxy_to_broker_url,json=proxyToBrokerUrl" json:"proxy_to_broker_url,omitempty"`
	// Original principal that was verified by
	// a Pulsar proxy. In this case the auth info above
	// will be the auth of the proxy itself
	OriginalPrincipal *string `protobuf:"bytes,7,opt,name=original_principal,json=originalPrincipal" json:"original_principal,omitempty"`
	// Original auth role and auth Method that was passed
	// to the proxy. In this case the auth info above
	// will be the auth of the proxy itself
	OriginalAuthData     *string  `protobuf:"bytes,8,opt,name=original_auth_data,json=originalAuthData" json:"original_auth_data,omitempty"`
	OriginalAuthMethod   *string  `protobuf:"bytes,9,opt,name=original_auth_method,json=originalAuthMethod" json:"original_auth_method,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandConnect) Descriptor

func (*CommandConnect) Descriptor() ([]byte, []int)

func (*CommandConnect) GetAuthData

func (m *CommandConnect) GetAuthData() []byte

func (*CommandConnect) GetAuthMethod

func (m *CommandConnect) GetAuthMethod() AuthMethod

func (*CommandConnect) GetAuthMethodName

func (m *CommandConnect) GetAuthMethodName() string

func (*CommandConnect) GetClientVersion

func (m *CommandConnect) GetClientVersion() string

func (*CommandConnect) GetOriginalAuthData

func (m *CommandConnect) GetOriginalAuthData() string

func (*CommandConnect) GetOriginalAuthMethod

func (m *CommandConnect) GetOriginalAuthMethod() string

func (*CommandConnect) GetOriginalPrincipal

func (m *CommandConnect) GetOriginalPrincipal() string

func (*CommandConnect) GetProtocolVersion

func (m *CommandConnect) GetProtocolVersion() int32

func (*CommandConnect) GetProxyToBrokerUrl

func (m *CommandConnect) GetProxyToBrokerUrl() string

func (*CommandConnect) Marshal

func (m *CommandConnect) Marshal() (dAtA []byte, err error)

func (*CommandConnect) MarshalTo

func (m *CommandConnect) MarshalTo(dAtA []byte) (int, error)

func (*CommandConnect) MarshalToSizedBuffer

func (m *CommandConnect) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandConnect) ProtoMessage

func (*CommandConnect) ProtoMessage()

func (*CommandConnect) Reset

func (m *CommandConnect) Reset()

func (*CommandConnect) Size

func (m *CommandConnect) Size() (n int)

func (*CommandConnect) String

func (m *CommandConnect) String() string

func (*CommandConnect) Unmarshal

func (m *CommandConnect) Unmarshal(dAtA []byte) error

func (*CommandConnect) XXX_DiscardUnknown

func (m *CommandConnect) XXX_DiscardUnknown()

func (*CommandConnect) XXX_Marshal

func (m *CommandConnect) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandConnect) XXX_Merge

func (m *CommandConnect) XXX_Merge(src proto.Message)

func (*CommandConnect) XXX_Size

func (m *CommandConnect) XXX_Size() int

func (*CommandConnect) XXX_Unmarshal

func (m *CommandConnect) XXX_Unmarshal(b []byte) error

type CommandConnected

type CommandConnected struct {
	ServerVersion        *string  `protobuf:"bytes,1,req,name=server_version,json=serverVersion" json:"server_version,omitempty"`
	ProtocolVersion      *int32   `protobuf:"varint,2,opt,name=protocol_version,json=protocolVersion,def=0" json:"protocol_version,omitempty"`
	MaxMessageSize       *int32   `protobuf:"varint,3,opt,name=max_message_size,json=maxMessageSize" json:"max_message_size,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandConnected) Descriptor

func (*CommandConnected) Descriptor() ([]byte, []int)

func (*CommandConnected) GetMaxMessageSize

func (m *CommandConnected) GetMaxMessageSize() int32

func (*CommandConnected) GetProtocolVersion

func (m *CommandConnected) GetProtocolVersion() int32

func (*CommandConnected) GetServerVersion

func (m *CommandConnected) GetServerVersion() string

func (*CommandConnected) Marshal

func (m *CommandConnected) Marshal() (dAtA []byte, err error)

func (*CommandConnected) MarshalTo

func (m *CommandConnected) MarshalTo(dAtA []byte) (int, error)

func (*CommandConnected) MarshalToSizedBuffer

func (m *CommandConnected) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandConnected) ProtoMessage

func (*CommandConnected) ProtoMessage()

func (*CommandConnected) Reset

func (m *CommandConnected) Reset()

func (*CommandConnected) Size

func (m *CommandConnected) Size() (n int)

func (*CommandConnected) String

func (m *CommandConnected) String() string

func (*CommandConnected) Unmarshal

func (m *CommandConnected) Unmarshal(dAtA []byte) error

func (*CommandConnected) XXX_DiscardUnknown

func (m *CommandConnected) XXX_DiscardUnknown()

func (*CommandConnected) XXX_Marshal

func (m *CommandConnected) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandConnected) XXX_Merge

func (m *CommandConnected) XXX_Merge(src proto.Message)

func (*CommandConnected) XXX_Size

func (m *CommandConnected) XXX_Size() int

func (*CommandConnected) XXX_Unmarshal

func (m *CommandConnected) XXX_Unmarshal(b []byte) error

type CommandConsumerStats

type CommandConsumerStats struct {
	RequestId *uint64 `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	// required string topic_name         = 2;
	// required string subscription_name  = 3;
	ConsumerId           *uint64  `protobuf:"varint,4,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandConsumerStats) Descriptor

func (*CommandConsumerStats) Descriptor() ([]byte, []int)

func (*CommandConsumerStats) GetConsumerId

func (m *CommandConsumerStats) GetConsumerId() uint64

func (*CommandConsumerStats) GetRequestId

func (m *CommandConsumerStats) GetRequestId() uint64

func (*CommandConsumerStats) Marshal

func (m *CommandConsumerStats) Marshal() (dAtA []byte, err error)

func (*CommandConsumerStats) MarshalTo

func (m *CommandConsumerStats) MarshalTo(dAtA []byte) (int, error)

func (*CommandConsumerStats) MarshalToSizedBuffer

func (m *CommandConsumerStats) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandConsumerStats) ProtoMessage

func (*CommandConsumerStats) ProtoMessage()

func (*CommandConsumerStats) Reset

func (m *CommandConsumerStats) Reset()

func (*CommandConsumerStats) Size

func (m *CommandConsumerStats) Size() (n int)

func (*CommandConsumerStats) String

func (m *CommandConsumerStats) String() string

func (*CommandConsumerStats) Unmarshal

func (m *CommandConsumerStats) Unmarshal(dAtA []byte) error

func (*CommandConsumerStats) XXX_DiscardUnknown

func (m *CommandConsumerStats) XXX_DiscardUnknown()

func (*CommandConsumerStats) XXX_Marshal

func (m *CommandConsumerStats) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandConsumerStats) XXX_Merge

func (m *CommandConsumerStats) XXX_Merge(src proto.Message)

func (*CommandConsumerStats) XXX_Size

func (m *CommandConsumerStats) XXX_Size() int

func (*CommandConsumerStats) XXX_Unmarshal

func (m *CommandConsumerStats) XXX_Unmarshal(b []byte) error

type CommandConsumerStatsResponse

type CommandConsumerStatsResponse struct {
	RequestId    *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	ErrorCode    *ServerError `protobuf:"varint,2,opt,name=error_code,json=errorCode,enum=pulsar.proto.ServerError" json:"error_code,omitempty"`
	ErrorMessage *string      `protobuf:"bytes,3,opt,name=error_message,json=errorMessage" json:"error_message,omitempty"`
	/// Total rate of messages delivered to the consumer. msg/s
	MsgRateOut *float64 `protobuf:"fixed64,4,opt,name=msgRateOut" json:"msgRateOut,omitempty"`
	/// Total throughput delivered to the consumer. bytes/s
	MsgThroughputOut *float64 `protobuf:"fixed64,5,opt,name=msgThroughputOut" json:"msgThroughputOut,omitempty"`
	/// Total rate of messages redelivered by this consumer. msg/s
	MsgRateRedeliver *float64 `protobuf:"fixed64,6,opt,name=msgRateRedeliver" json:"msgRateRedeliver,omitempty"`
	/// Name of the consumer
	ConsumerName *string `protobuf:"bytes,7,opt,name=consumerName" json:"consumerName,omitempty"`
	/// Number of available message permits for the consumer
	AvailablePermits *uint64 `protobuf:"varint,8,opt,name=availablePermits" json:"availablePermits,omitempty"`
	/// Number of unacknowledged messages for the consumer
	UnackedMessages *uint64 `protobuf:"varint,9,opt,name=unackedMessages" json:"unackedMessages,omitempty"`
	/// Flag to verify if consumer is blocked due to reaching threshold of unacked messages
	BlockedConsumerOnUnackedMsgs *bool `protobuf:"varint,10,opt,name=blockedConsumerOnUnackedMsgs" json:"blockedConsumerOnUnackedMsgs,omitempty"`
	/// Address of this consumer
	Address *string `protobuf:"bytes,11,opt,name=address" json:"address,omitempty"`
	/// Timestamp of connection
	ConnectedSince *string `protobuf:"bytes,12,opt,name=connectedSince" json:"connectedSince,omitempty"`
	/// Whether this subscription is Exclusive or Shared or Failover
	Type *string `protobuf:"bytes,13,opt,name=type" json:"type,omitempty"`
	/// Total rate of messages expired on this subscription. msg/s
	MsgRateExpired *float64 `protobuf:"fixed64,14,opt,name=msgRateExpired" json:"msgRateExpired,omitempty"`
	/// Number of messages in the subscription backlog
	MsgBacklog           *uint64  `protobuf:"varint,15,opt,name=msgBacklog" json:"msgBacklog,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandConsumerStatsResponse) Descriptor

func (*CommandConsumerStatsResponse) Descriptor() ([]byte, []int)

func (*CommandConsumerStatsResponse) GetAddress

func (m *CommandConsumerStatsResponse) GetAddress() string

func (*CommandConsumerStatsResponse) GetAvailablePermits

func (m *CommandConsumerStatsResponse) GetAvailablePermits() uint64

func (*CommandConsumerStatsResponse) GetBlockedConsumerOnUnackedMsgs

func (m *CommandConsumerStatsResponse) GetBlockedConsumerOnUnackedMsgs() bool

func (*CommandConsumerStatsResponse) GetConnectedSince

func (m *CommandConsumerStatsResponse) GetConnectedSince() string

func (*CommandConsumerStatsResponse) GetConsumerName

func (m *CommandConsumerStatsResponse) GetConsumerName() string

func (*CommandConsumerStatsResponse) GetErrorCode

func (m *CommandConsumerStatsResponse) GetErrorCode() ServerError

func (*CommandConsumerStatsResponse) GetErrorMessage

func (m *CommandConsumerStatsResponse) GetErrorMessage() string

func (*CommandConsumerStatsResponse) GetMsgBacklog

func (m *CommandConsumerStatsResponse) GetMsgBacklog() uint64

func (*CommandConsumerStatsResponse) GetMsgRateExpired

func (m *CommandConsumerStatsResponse) GetMsgRateExpired() float64

func (*CommandConsumerStatsResponse) GetMsgRateOut

func (m *CommandConsumerStatsResponse) GetMsgRateOut() float64

func (*CommandConsumerStatsResponse) GetMsgRateRedeliver

func (m *CommandConsumerStatsResponse) GetMsgRateRedeliver() float64

func (*CommandConsumerStatsResponse) GetMsgThroughputOut

func (m *CommandConsumerStatsResponse) GetMsgThroughputOut() float64

func (*CommandConsumerStatsResponse) GetRequestId

func (m *CommandConsumerStatsResponse) GetRequestId() uint64

func (*CommandConsumerStatsResponse) GetType

func (m *CommandConsumerStatsResponse) GetType() string

func (*CommandConsumerStatsResponse) GetUnackedMessages

func (m *CommandConsumerStatsResponse) GetUnackedMessages() uint64

func (*CommandConsumerStatsResponse) Marshal

func (m *CommandConsumerStatsResponse) Marshal() (dAtA []byte, err error)

func (*CommandConsumerStatsResponse) MarshalTo

func (m *CommandConsumerStatsResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandConsumerStatsResponse) MarshalToSizedBuffer

func (m *CommandConsumerStatsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandConsumerStatsResponse) ProtoMessage

func (*CommandConsumerStatsResponse) ProtoMessage()

func (*CommandConsumerStatsResponse) Reset

func (m *CommandConsumerStatsResponse) Reset()

func (*CommandConsumerStatsResponse) Size

func (m *CommandConsumerStatsResponse) Size() (n int)

func (*CommandConsumerStatsResponse) String

func (*CommandConsumerStatsResponse) Unmarshal

func (m *CommandConsumerStatsResponse) Unmarshal(dAtA []byte) error

func (*CommandConsumerStatsResponse) XXX_DiscardUnknown

func (m *CommandConsumerStatsResponse) XXX_DiscardUnknown()

func (*CommandConsumerStatsResponse) XXX_Marshal

func (m *CommandConsumerStatsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandConsumerStatsResponse) XXX_Merge

func (m *CommandConsumerStatsResponse) XXX_Merge(src proto.Message)

func (*CommandConsumerStatsResponse) XXX_Size

func (m *CommandConsumerStatsResponse) XXX_Size() int

func (*CommandConsumerStatsResponse) XXX_Unmarshal

func (m *CommandConsumerStatsResponse) XXX_Unmarshal(b []byte) error

type CommandEndTxn

type CommandEndTxn struct {
	RequestId            *uint64    `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64    `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64    `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	TxnAction            *TxnAction `protobuf:"varint,4,opt,name=txn_action,json=txnAction,enum=pulsar.proto.TxnAction" json:"txn_action,omitempty"`
	XXX_NoUnkeyedLiteral struct{}   `json:"-"`
	XXX_unrecognized     []byte     `json:"-"`
	XXX_sizecache        int32      `json:"-"`
}

func (*CommandEndTxn) Descriptor

func (*CommandEndTxn) Descriptor() ([]byte, []int)

func (*CommandEndTxn) GetRequestId

func (m *CommandEndTxn) GetRequestId() uint64

func (*CommandEndTxn) GetTxnAction

func (m *CommandEndTxn) GetTxnAction() TxnAction

func (*CommandEndTxn) GetTxnidLeastBits

func (m *CommandEndTxn) GetTxnidLeastBits() uint64

func (*CommandEndTxn) GetTxnidMostBits

func (m *CommandEndTxn) GetTxnidMostBits() uint64

func (*CommandEndTxn) Marshal

func (m *CommandEndTxn) Marshal() (dAtA []byte, err error)

func (*CommandEndTxn) MarshalTo

func (m *CommandEndTxn) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxn) MarshalToSizedBuffer

func (m *CommandEndTxn) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxn) ProtoMessage

func (*CommandEndTxn) ProtoMessage()

func (*CommandEndTxn) Reset

func (m *CommandEndTxn) Reset()

func (*CommandEndTxn) Size

func (m *CommandEndTxn) Size() (n int)

func (*CommandEndTxn) String

func (m *CommandEndTxn) String() string

func (*CommandEndTxn) Unmarshal

func (m *CommandEndTxn) Unmarshal(dAtA []byte) error

func (*CommandEndTxn) XXX_DiscardUnknown

func (m *CommandEndTxn) XXX_DiscardUnknown()

func (*CommandEndTxn) XXX_Marshal

func (m *CommandEndTxn) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxn) XXX_Merge

func (m *CommandEndTxn) XXX_Merge(src proto.Message)

func (*CommandEndTxn) XXX_Size

func (m *CommandEndTxn) XXX_Size() int

func (*CommandEndTxn) XXX_Unmarshal

func (m *CommandEndTxn) XXX_Unmarshal(b []byte) error

type CommandEndTxnOnPartition

type CommandEndTxnOnPartition struct {
	RequestId            *uint64    `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64    `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64    `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Topic                *string    `protobuf:"bytes,4,opt,name=topic" json:"topic,omitempty"`
	TxnAction            *TxnAction `protobuf:"varint,5,opt,name=txn_action,json=txnAction,enum=pulsar.proto.TxnAction" json:"txn_action,omitempty"`
	XXX_NoUnkeyedLiteral struct{}   `json:"-"`
	XXX_unrecognized     []byte     `json:"-"`
	XXX_sizecache        int32      `json:"-"`
}

func (*CommandEndTxnOnPartition) Descriptor

func (*CommandEndTxnOnPartition) Descriptor() ([]byte, []int)

func (*CommandEndTxnOnPartition) GetRequestId

func (m *CommandEndTxnOnPartition) GetRequestId() uint64

func (*CommandEndTxnOnPartition) GetTopic

func (m *CommandEndTxnOnPartition) GetTopic() string

func (*CommandEndTxnOnPartition) GetTxnAction

func (m *CommandEndTxnOnPartition) GetTxnAction() TxnAction

func (*CommandEndTxnOnPartition) GetTxnidLeastBits

func (m *CommandEndTxnOnPartition) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnPartition) GetTxnidMostBits

func (m *CommandEndTxnOnPartition) GetTxnidMostBits() uint64

func (*CommandEndTxnOnPartition) Marshal

func (m *CommandEndTxnOnPartition) Marshal() (dAtA []byte, err error)

func (*CommandEndTxnOnPartition) MarshalTo

func (m *CommandEndTxnOnPartition) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxnOnPartition) MarshalToSizedBuffer

func (m *CommandEndTxnOnPartition) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxnOnPartition) ProtoMessage

func (*CommandEndTxnOnPartition) ProtoMessage()

func (*CommandEndTxnOnPartition) Reset

func (m *CommandEndTxnOnPartition) Reset()

func (*CommandEndTxnOnPartition) Size

func (m *CommandEndTxnOnPartition) Size() (n int)

func (*CommandEndTxnOnPartition) String

func (m *CommandEndTxnOnPartition) String() string

func (*CommandEndTxnOnPartition) Unmarshal

func (m *CommandEndTxnOnPartition) Unmarshal(dAtA []byte) error

func (*CommandEndTxnOnPartition) XXX_DiscardUnknown

func (m *CommandEndTxnOnPartition) XXX_DiscardUnknown()

func (*CommandEndTxnOnPartition) XXX_Marshal

func (m *CommandEndTxnOnPartition) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxnOnPartition) XXX_Merge

func (m *CommandEndTxnOnPartition) XXX_Merge(src proto.Message)

func (*CommandEndTxnOnPartition) XXX_Size

func (m *CommandEndTxnOnPartition) XXX_Size() int

func (*CommandEndTxnOnPartition) XXX_Unmarshal

func (m *CommandEndTxnOnPartition) XXX_Unmarshal(b []byte) error

type CommandEndTxnOnPartitionResponse

type CommandEndTxnOnPartitionResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandEndTxnOnPartitionResponse) Descriptor

func (*CommandEndTxnOnPartitionResponse) Descriptor() ([]byte, []int)

func (*CommandEndTxnOnPartitionResponse) GetError

func (*CommandEndTxnOnPartitionResponse) GetMessage

func (m *CommandEndTxnOnPartitionResponse) GetMessage() string

func (*CommandEndTxnOnPartitionResponse) GetRequestId

func (m *CommandEndTxnOnPartitionResponse) GetRequestId() uint64

func (*CommandEndTxnOnPartitionResponse) GetTxnidLeastBits

func (m *CommandEndTxnOnPartitionResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnPartitionResponse) GetTxnidMostBits

func (m *CommandEndTxnOnPartitionResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnOnPartitionResponse) Marshal

func (m *CommandEndTxnOnPartitionResponse) Marshal() (dAtA []byte, err error)

func (*CommandEndTxnOnPartitionResponse) MarshalTo

func (m *CommandEndTxnOnPartitionResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxnOnPartitionResponse) MarshalToSizedBuffer

func (m *CommandEndTxnOnPartitionResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxnOnPartitionResponse) ProtoMessage

func (*CommandEndTxnOnPartitionResponse) ProtoMessage()

func (*CommandEndTxnOnPartitionResponse) Reset

func (*CommandEndTxnOnPartitionResponse) Size

func (m *CommandEndTxnOnPartitionResponse) Size() (n int)

func (*CommandEndTxnOnPartitionResponse) String

func (*CommandEndTxnOnPartitionResponse) Unmarshal

func (m *CommandEndTxnOnPartitionResponse) Unmarshal(dAtA []byte) error

func (*CommandEndTxnOnPartitionResponse) XXX_DiscardUnknown

func (m *CommandEndTxnOnPartitionResponse) XXX_DiscardUnknown()

func (*CommandEndTxnOnPartitionResponse) XXX_Marshal

func (m *CommandEndTxnOnPartitionResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxnOnPartitionResponse) XXX_Merge

func (*CommandEndTxnOnPartitionResponse) XXX_Size

func (m *CommandEndTxnOnPartitionResponse) XXX_Size() int

func (*CommandEndTxnOnPartitionResponse) XXX_Unmarshal

func (m *CommandEndTxnOnPartitionResponse) XXX_Unmarshal(b []byte) error

type CommandEndTxnOnSubscription

type CommandEndTxnOnSubscription struct {
	RequestId            *uint64       `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64       `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64       `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Subscription         *Subscription `protobuf:"bytes,4,opt,name=subscription" json:"subscription,omitempty"`
	TxnAction            *TxnAction    `protobuf:"varint,5,opt,name=txn_action,json=txnAction,enum=pulsar.proto.TxnAction" json:"txn_action,omitempty"`
	XXX_NoUnkeyedLiteral struct{}      `json:"-"`
	XXX_unrecognized     []byte        `json:"-"`
	XXX_sizecache        int32         `json:"-"`
}

func (*CommandEndTxnOnSubscription) Descriptor

func (*CommandEndTxnOnSubscription) Descriptor() ([]byte, []int)

func (*CommandEndTxnOnSubscription) GetRequestId

func (m *CommandEndTxnOnSubscription) GetRequestId() uint64

func (*CommandEndTxnOnSubscription) GetSubscription

func (m *CommandEndTxnOnSubscription) GetSubscription() *Subscription

func (*CommandEndTxnOnSubscription) GetTxnAction

func (m *CommandEndTxnOnSubscription) GetTxnAction() TxnAction

func (*CommandEndTxnOnSubscription) GetTxnidLeastBits

func (m *CommandEndTxnOnSubscription) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnSubscription) GetTxnidMostBits

func (m *CommandEndTxnOnSubscription) GetTxnidMostBits() uint64

func (*CommandEndTxnOnSubscription) Marshal

func (m *CommandEndTxnOnSubscription) Marshal() (dAtA []byte, err error)

func (*CommandEndTxnOnSubscription) MarshalTo

func (m *CommandEndTxnOnSubscription) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxnOnSubscription) MarshalToSizedBuffer

func (m *CommandEndTxnOnSubscription) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxnOnSubscription) ProtoMessage

func (*CommandEndTxnOnSubscription) ProtoMessage()

func (*CommandEndTxnOnSubscription) Reset

func (m *CommandEndTxnOnSubscription) Reset()

func (*CommandEndTxnOnSubscription) Size

func (m *CommandEndTxnOnSubscription) Size() (n int)

func (*CommandEndTxnOnSubscription) String

func (m *CommandEndTxnOnSubscription) String() string

func (*CommandEndTxnOnSubscription) Unmarshal

func (m *CommandEndTxnOnSubscription) Unmarshal(dAtA []byte) error

func (*CommandEndTxnOnSubscription) XXX_DiscardUnknown

func (m *CommandEndTxnOnSubscription) XXX_DiscardUnknown()

func (*CommandEndTxnOnSubscription) XXX_Marshal

func (m *CommandEndTxnOnSubscription) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxnOnSubscription) XXX_Merge

func (m *CommandEndTxnOnSubscription) XXX_Merge(src proto.Message)

func (*CommandEndTxnOnSubscription) XXX_Size

func (m *CommandEndTxnOnSubscription) XXX_Size() int

func (*CommandEndTxnOnSubscription) XXX_Unmarshal

func (m *CommandEndTxnOnSubscription) XXX_Unmarshal(b []byte) error

type CommandEndTxnOnSubscriptionResponse

type CommandEndTxnOnSubscriptionResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandEndTxnOnSubscriptionResponse) Descriptor

func (*CommandEndTxnOnSubscriptionResponse) Descriptor() ([]byte, []int)

func (*CommandEndTxnOnSubscriptionResponse) GetError

func (*CommandEndTxnOnSubscriptionResponse) GetMessage

func (*CommandEndTxnOnSubscriptionResponse) GetRequestId

func (m *CommandEndTxnOnSubscriptionResponse) GetRequestId() uint64

func (*CommandEndTxnOnSubscriptionResponse) GetTxnidLeastBits

func (m *CommandEndTxnOnSubscriptionResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnSubscriptionResponse) GetTxnidMostBits

func (m *CommandEndTxnOnSubscriptionResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnOnSubscriptionResponse) Marshal

func (m *CommandEndTxnOnSubscriptionResponse) Marshal() (dAtA []byte, err error)

func (*CommandEndTxnOnSubscriptionResponse) MarshalTo

func (m *CommandEndTxnOnSubscriptionResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxnOnSubscriptionResponse) MarshalToSizedBuffer

func (m *CommandEndTxnOnSubscriptionResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxnOnSubscriptionResponse) ProtoMessage

func (*CommandEndTxnOnSubscriptionResponse) ProtoMessage()

func (*CommandEndTxnOnSubscriptionResponse) Reset

func (*CommandEndTxnOnSubscriptionResponse) Size

func (*CommandEndTxnOnSubscriptionResponse) String

func (*CommandEndTxnOnSubscriptionResponse) Unmarshal

func (m *CommandEndTxnOnSubscriptionResponse) Unmarshal(dAtA []byte) error

func (*CommandEndTxnOnSubscriptionResponse) XXX_DiscardUnknown

func (m *CommandEndTxnOnSubscriptionResponse) XXX_DiscardUnknown()

func (*CommandEndTxnOnSubscriptionResponse) XXX_Marshal

func (m *CommandEndTxnOnSubscriptionResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxnOnSubscriptionResponse) XXX_Merge

func (*CommandEndTxnOnSubscriptionResponse) XXX_Size

func (*CommandEndTxnOnSubscriptionResponse) XXX_Unmarshal

func (m *CommandEndTxnOnSubscriptionResponse) XXX_Unmarshal(b []byte) error

type CommandEndTxnResponse

type CommandEndTxnResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandEndTxnResponse) Descriptor

func (*CommandEndTxnResponse) Descriptor() ([]byte, []int)

func (*CommandEndTxnResponse) GetError

func (m *CommandEndTxnResponse) GetError() ServerError

func (*CommandEndTxnResponse) GetMessage

func (m *CommandEndTxnResponse) GetMessage() string

func (*CommandEndTxnResponse) GetRequestId

func (m *CommandEndTxnResponse) GetRequestId() uint64

func (*CommandEndTxnResponse) GetTxnidLeastBits

func (m *CommandEndTxnResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnResponse) GetTxnidMostBits

func (m *CommandEndTxnResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnResponse) Marshal

func (m *CommandEndTxnResponse) Marshal() (dAtA []byte, err error)

func (*CommandEndTxnResponse) MarshalTo

func (m *CommandEndTxnResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandEndTxnResponse) MarshalToSizedBuffer

func (m *CommandEndTxnResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandEndTxnResponse) ProtoMessage

func (*CommandEndTxnResponse) ProtoMessage()

func (*CommandEndTxnResponse) Reset

func (m *CommandEndTxnResponse) Reset()

func (*CommandEndTxnResponse) Size

func (m *CommandEndTxnResponse) Size() (n int)

func (*CommandEndTxnResponse) String

func (m *CommandEndTxnResponse) String() string

func (*CommandEndTxnResponse) Unmarshal

func (m *CommandEndTxnResponse) Unmarshal(dAtA []byte) error

func (*CommandEndTxnResponse) XXX_DiscardUnknown

func (m *CommandEndTxnResponse) XXX_DiscardUnknown()

func (*CommandEndTxnResponse) XXX_Marshal

func (m *CommandEndTxnResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandEndTxnResponse) XXX_Merge

func (m *CommandEndTxnResponse) XXX_Merge(src proto.Message)

func (*CommandEndTxnResponse) XXX_Size

func (m *CommandEndTxnResponse) XXX_Size() int

func (*CommandEndTxnResponse) XXX_Unmarshal

func (m *CommandEndTxnResponse) XXX_Unmarshal(b []byte) error

type CommandError

type CommandError struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Error                *ServerError `protobuf:"varint,2,req,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,3,req,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandError) Descriptor

func (*CommandError) Descriptor() ([]byte, []int)

func (*CommandError) GetError

func (m *CommandError) GetError() ServerError

func (*CommandError) GetMessage

func (m *CommandError) GetMessage() string

func (*CommandError) GetRequestId

func (m *CommandError) GetRequestId() uint64

func (*CommandError) Marshal

func (m *CommandError) Marshal() (dAtA []byte, err error)

func (*CommandError) MarshalTo

func (m *CommandError) MarshalTo(dAtA []byte) (int, error)

func (*CommandError) MarshalToSizedBuffer

func (m *CommandError) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandError) ProtoMessage

func (*CommandError) ProtoMessage()

func (*CommandError) Reset

func (m *CommandError) Reset()

func (*CommandError) Size

func (m *CommandError) Size() (n int)

func (*CommandError) String

func (m *CommandError) String() string

func (*CommandError) Unmarshal

func (m *CommandError) Unmarshal(dAtA []byte) error

func (*CommandError) XXX_DiscardUnknown

func (m *CommandError) XXX_DiscardUnknown()

func (*CommandError) XXX_Marshal

func (m *CommandError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandError) XXX_Merge

func (m *CommandError) XXX_Merge(src proto.Message)

func (*CommandError) XXX_Size

func (m *CommandError) XXX_Size() int

func (*CommandError) XXX_Unmarshal

func (m *CommandError) XXX_Unmarshal(b []byte) error

type CommandFlow

type CommandFlow struct {
	ConsumerId *uint64 `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	// Max number of messages to prefetch, in addition
	// of any number previously specified
	MessagePermits       *uint32  `protobuf:"varint,2,req,name=messagePermits" json:"messagePermits,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandFlow) Descriptor

func (*CommandFlow) Descriptor() ([]byte, []int)

func (*CommandFlow) GetConsumerId

func (m *CommandFlow) GetConsumerId() uint64

func (*CommandFlow) GetMessagePermits

func (m *CommandFlow) GetMessagePermits() uint32

func (*CommandFlow) Marshal

func (m *CommandFlow) Marshal() (dAtA []byte, err error)

func (*CommandFlow) MarshalTo

func (m *CommandFlow) MarshalTo(dAtA []byte) (int, error)

func (*CommandFlow) MarshalToSizedBuffer

func (m *CommandFlow) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandFlow) ProtoMessage

func (*CommandFlow) ProtoMessage()

func (*CommandFlow) Reset

func (m *CommandFlow) Reset()

func (*CommandFlow) Size

func (m *CommandFlow) Size() (n int)

func (*CommandFlow) String

func (m *CommandFlow) String() string

func (*CommandFlow) Unmarshal

func (m *CommandFlow) Unmarshal(dAtA []byte) error

func (*CommandFlow) XXX_DiscardUnknown

func (m *CommandFlow) XXX_DiscardUnknown()

func (*CommandFlow) XXX_Marshal

func (m *CommandFlow) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandFlow) XXX_Merge

func (m *CommandFlow) XXX_Merge(src proto.Message)

func (*CommandFlow) XXX_Size

func (m *CommandFlow) XXX_Size() int

func (*CommandFlow) XXX_Unmarshal

func (m *CommandFlow) XXX_Unmarshal(b []byte) error

type CommandGetLastMessageId

type CommandGetLastMessageId struct {
	ConsumerId           *uint64  `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	RequestId            *uint64  `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandGetLastMessageId) Descriptor

func (*CommandGetLastMessageId) Descriptor() ([]byte, []int)

func (*CommandGetLastMessageId) GetConsumerId

func (m *CommandGetLastMessageId) GetConsumerId() uint64

func (*CommandGetLastMessageId) GetRequestId

func (m *CommandGetLastMessageId) GetRequestId() uint64

func (*CommandGetLastMessageId) Marshal

func (m *CommandGetLastMessageId) Marshal() (dAtA []byte, err error)

func (*CommandGetLastMessageId) MarshalTo

func (m *CommandGetLastMessageId) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetLastMessageId) MarshalToSizedBuffer

func (m *CommandGetLastMessageId) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetLastMessageId) ProtoMessage

func (*CommandGetLastMessageId) ProtoMessage()

func (*CommandGetLastMessageId) Reset

func (m *CommandGetLastMessageId) Reset()

func (*CommandGetLastMessageId) Size

func (m *CommandGetLastMessageId) Size() (n int)

func (*CommandGetLastMessageId) String

func (m *CommandGetLastMessageId) String() string

func (*CommandGetLastMessageId) Unmarshal

func (m *CommandGetLastMessageId) Unmarshal(dAtA []byte) error

func (*CommandGetLastMessageId) XXX_DiscardUnknown

func (m *CommandGetLastMessageId) XXX_DiscardUnknown()

func (*CommandGetLastMessageId) XXX_Marshal

func (m *CommandGetLastMessageId) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetLastMessageId) XXX_Merge

func (m *CommandGetLastMessageId) XXX_Merge(src proto.Message)

func (*CommandGetLastMessageId) XXX_Size

func (m *CommandGetLastMessageId) XXX_Size() int

func (*CommandGetLastMessageId) XXX_Unmarshal

func (m *CommandGetLastMessageId) XXX_Unmarshal(b []byte) error

type CommandGetLastMessageIdResponse

type CommandGetLastMessageIdResponse struct {
	LastMessageId        *MessageIdData `protobuf:"bytes,1,req,name=last_message_id,json=lastMessageId" json:"last_message_id,omitempty"`
	RequestId            *uint64        `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{}       `json:"-"`
	XXX_unrecognized     []byte         `json:"-"`
	XXX_sizecache        int32          `json:"-"`
}

func (*CommandGetLastMessageIdResponse) Descriptor

func (*CommandGetLastMessageIdResponse) Descriptor() ([]byte, []int)

func (*CommandGetLastMessageIdResponse) GetLastMessageId

func (m *CommandGetLastMessageIdResponse) GetLastMessageId() *MessageIdData

func (*CommandGetLastMessageIdResponse) GetRequestId

func (m *CommandGetLastMessageIdResponse) GetRequestId() uint64

func (*CommandGetLastMessageIdResponse) Marshal

func (m *CommandGetLastMessageIdResponse) Marshal() (dAtA []byte, err error)

func (*CommandGetLastMessageIdResponse) MarshalTo

func (m *CommandGetLastMessageIdResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetLastMessageIdResponse) MarshalToSizedBuffer

func (m *CommandGetLastMessageIdResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetLastMessageIdResponse) ProtoMessage

func (*CommandGetLastMessageIdResponse) ProtoMessage()

func (*CommandGetLastMessageIdResponse) Reset

func (*CommandGetLastMessageIdResponse) Size

func (m *CommandGetLastMessageIdResponse) Size() (n int)

func (*CommandGetLastMessageIdResponse) String

func (*CommandGetLastMessageIdResponse) Unmarshal

func (m *CommandGetLastMessageIdResponse) Unmarshal(dAtA []byte) error

func (*CommandGetLastMessageIdResponse) XXX_DiscardUnknown

func (m *CommandGetLastMessageIdResponse) XXX_DiscardUnknown()

func (*CommandGetLastMessageIdResponse) XXX_Marshal

func (m *CommandGetLastMessageIdResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetLastMessageIdResponse) XXX_Merge

func (m *CommandGetLastMessageIdResponse) XXX_Merge(src proto.Message)

func (*CommandGetLastMessageIdResponse) XXX_Size

func (m *CommandGetLastMessageIdResponse) XXX_Size() int

func (*CommandGetLastMessageIdResponse) XXX_Unmarshal

func (m *CommandGetLastMessageIdResponse) XXX_Unmarshal(b []byte) error

type CommandGetOrCreateSchema

type CommandGetOrCreateSchema struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Topic                *string  `protobuf:"bytes,2,req,name=topic" json:"topic,omitempty"`
	Schema               *Schema  `protobuf:"bytes,3,req,name=schema" json:"schema,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandGetOrCreateSchema) Descriptor

func (*CommandGetOrCreateSchema) Descriptor() ([]byte, []int)

func (*CommandGetOrCreateSchema) GetRequestId

func (m *CommandGetOrCreateSchema) GetRequestId() uint64

func (*CommandGetOrCreateSchema) GetSchema

func (m *CommandGetOrCreateSchema) GetSchema() *Schema

func (*CommandGetOrCreateSchema) GetTopic

func (m *CommandGetOrCreateSchema) GetTopic() string

func (*CommandGetOrCreateSchema) Marshal

func (m *CommandGetOrCreateSchema) Marshal() (dAtA []byte, err error)

func (*CommandGetOrCreateSchema) MarshalTo

func (m *CommandGetOrCreateSchema) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetOrCreateSchema) MarshalToSizedBuffer

func (m *CommandGetOrCreateSchema) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetOrCreateSchema) ProtoMessage

func (*CommandGetOrCreateSchema) ProtoMessage()

func (*CommandGetOrCreateSchema) Reset

func (m *CommandGetOrCreateSchema) Reset()

func (*CommandGetOrCreateSchema) Size

func (m *CommandGetOrCreateSchema) Size() (n int)

func (*CommandGetOrCreateSchema) String

func (m *CommandGetOrCreateSchema) String() string

func (*CommandGetOrCreateSchema) Unmarshal

func (m *CommandGetOrCreateSchema) Unmarshal(dAtA []byte) error

func (*CommandGetOrCreateSchema) XXX_DiscardUnknown

func (m *CommandGetOrCreateSchema) XXX_DiscardUnknown()

func (*CommandGetOrCreateSchema) XXX_Marshal

func (m *CommandGetOrCreateSchema) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetOrCreateSchema) XXX_Merge

func (m *CommandGetOrCreateSchema) XXX_Merge(src proto.Message)

func (*CommandGetOrCreateSchema) XXX_Size

func (m *CommandGetOrCreateSchema) XXX_Size() int

func (*CommandGetOrCreateSchema) XXX_Unmarshal

func (m *CommandGetOrCreateSchema) XXX_Unmarshal(b []byte) error

type CommandGetOrCreateSchemaResponse

type CommandGetOrCreateSchemaResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	ErrorCode            *ServerError `protobuf:"varint,2,opt,name=error_code,json=errorCode,enum=pulsar.proto.ServerError" json:"error_code,omitempty"`
	ErrorMessage         *string      `protobuf:"bytes,3,opt,name=error_message,json=errorMessage" json:"error_message,omitempty"`
	SchemaVersion        []byte       `protobuf:"bytes,4,opt,name=schema_version,json=schemaVersion" json:"schema_version,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandGetOrCreateSchemaResponse) Descriptor

func (*CommandGetOrCreateSchemaResponse) Descriptor() ([]byte, []int)

func (*CommandGetOrCreateSchemaResponse) GetErrorCode

func (*CommandGetOrCreateSchemaResponse) GetErrorMessage

func (m *CommandGetOrCreateSchemaResponse) GetErrorMessage() string

func (*CommandGetOrCreateSchemaResponse) GetRequestId

func (m *CommandGetOrCreateSchemaResponse) GetRequestId() uint64

func (*CommandGetOrCreateSchemaResponse) GetSchemaVersion

func (m *CommandGetOrCreateSchemaResponse) GetSchemaVersion() []byte

func (*CommandGetOrCreateSchemaResponse) Marshal

func (m *CommandGetOrCreateSchemaResponse) Marshal() (dAtA []byte, err error)

func (*CommandGetOrCreateSchemaResponse) MarshalTo

func (m *CommandGetOrCreateSchemaResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetOrCreateSchemaResponse) MarshalToSizedBuffer

func (m *CommandGetOrCreateSchemaResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetOrCreateSchemaResponse) ProtoMessage

func (*CommandGetOrCreateSchemaResponse) ProtoMessage()

func (*CommandGetOrCreateSchemaResponse) Reset

func (*CommandGetOrCreateSchemaResponse) Size

func (m *CommandGetOrCreateSchemaResponse) Size() (n int)

func (*CommandGetOrCreateSchemaResponse) String

func (*CommandGetOrCreateSchemaResponse) Unmarshal

func (m *CommandGetOrCreateSchemaResponse) Unmarshal(dAtA []byte) error

func (*CommandGetOrCreateSchemaResponse) XXX_DiscardUnknown

func (m *CommandGetOrCreateSchemaResponse) XXX_DiscardUnknown()

func (*CommandGetOrCreateSchemaResponse) XXX_Marshal

func (m *CommandGetOrCreateSchemaResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetOrCreateSchemaResponse) XXX_Merge

func (*CommandGetOrCreateSchemaResponse) XXX_Size

func (m *CommandGetOrCreateSchemaResponse) XXX_Size() int

func (*CommandGetOrCreateSchemaResponse) XXX_Unmarshal

func (m *CommandGetOrCreateSchemaResponse) XXX_Unmarshal(b []byte) error

type CommandGetSchema

type CommandGetSchema struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Topic                *string  `protobuf:"bytes,2,req,name=topic" json:"topic,omitempty"`
	SchemaVersion        []byte   `protobuf:"bytes,3,opt,name=schema_version,json=schemaVersion" json:"schema_version,omitempty"`
	NetModel             *string  `protobuf:"bytes,4,opt,name=net_model,json=netModel" json:"net_model,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandGetSchema) Descriptor

func (*CommandGetSchema) Descriptor() ([]byte, []int)

func (*CommandGetSchema) GetNetModel

func (m *CommandGetSchema) GetNetModel() string

func (*CommandGetSchema) GetRequestId

func (m *CommandGetSchema) GetRequestId() uint64

func (*CommandGetSchema) GetSchemaVersion

func (m *CommandGetSchema) GetSchemaVersion() []byte

func (*CommandGetSchema) GetTopic

func (m *CommandGetSchema) GetTopic() string

func (*CommandGetSchema) Marshal

func (m *CommandGetSchema) Marshal() (dAtA []byte, err error)

func (*CommandGetSchema) MarshalTo

func (m *CommandGetSchema) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetSchema) MarshalToSizedBuffer

func (m *CommandGetSchema) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetSchema) ProtoMessage

func (*CommandGetSchema) ProtoMessage()

func (*CommandGetSchema) Reset

func (m *CommandGetSchema) Reset()

func (*CommandGetSchema) Size

func (m *CommandGetSchema) Size() (n int)

func (*CommandGetSchema) String

func (m *CommandGetSchema) String() string

func (*CommandGetSchema) Unmarshal

func (m *CommandGetSchema) Unmarshal(dAtA []byte) error

func (*CommandGetSchema) XXX_DiscardUnknown

func (m *CommandGetSchema) XXX_DiscardUnknown()

func (*CommandGetSchema) XXX_Marshal

func (m *CommandGetSchema) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetSchema) XXX_Merge

func (m *CommandGetSchema) XXX_Merge(src proto.Message)

func (*CommandGetSchema) XXX_Size

func (m *CommandGetSchema) XXX_Size() int

func (*CommandGetSchema) XXX_Unmarshal

func (m *CommandGetSchema) XXX_Unmarshal(b []byte) error

type CommandGetSchemaResponse

type CommandGetSchemaResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	ErrorCode            *ServerError `protobuf:"varint,2,opt,name=error_code,json=errorCode,enum=pulsar.proto.ServerError" json:"error_code,omitempty"`
	ErrorMessage         *string      `protobuf:"bytes,3,opt,name=error_message,json=errorMessage" json:"error_message,omitempty"`
	Schema               *Schema      `protobuf:"bytes,4,opt,name=schema" json:"schema,omitempty"`
	SchemaVersion        []byte       `protobuf:"bytes,5,opt,name=schema_version,json=schemaVersion" json:"schema_version,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandGetSchemaResponse) Descriptor

func (*CommandGetSchemaResponse) Descriptor() ([]byte, []int)

func (*CommandGetSchemaResponse) GetErrorCode

func (m *CommandGetSchemaResponse) GetErrorCode() ServerError

func (*CommandGetSchemaResponse) GetErrorMessage

func (m *CommandGetSchemaResponse) GetErrorMessage() string

func (*CommandGetSchemaResponse) GetRequestId

func (m *CommandGetSchemaResponse) GetRequestId() uint64

func (*CommandGetSchemaResponse) GetSchema

func (m *CommandGetSchemaResponse) GetSchema() *Schema

func (*CommandGetSchemaResponse) GetSchemaVersion

func (m *CommandGetSchemaResponse) GetSchemaVersion() []byte

func (*CommandGetSchemaResponse) Marshal

func (m *CommandGetSchemaResponse) Marshal() (dAtA []byte, err error)

func (*CommandGetSchemaResponse) MarshalTo

func (m *CommandGetSchemaResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetSchemaResponse) MarshalToSizedBuffer

func (m *CommandGetSchemaResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetSchemaResponse) ProtoMessage

func (*CommandGetSchemaResponse) ProtoMessage()

func (*CommandGetSchemaResponse) Reset

func (m *CommandGetSchemaResponse) Reset()

func (*CommandGetSchemaResponse) Size

func (m *CommandGetSchemaResponse) Size() (n int)

func (*CommandGetSchemaResponse) String

func (m *CommandGetSchemaResponse) String() string

func (*CommandGetSchemaResponse) Unmarshal

func (m *CommandGetSchemaResponse) Unmarshal(dAtA []byte) error

func (*CommandGetSchemaResponse) XXX_DiscardUnknown

func (m *CommandGetSchemaResponse) XXX_DiscardUnknown()

func (*CommandGetSchemaResponse) XXX_Marshal

func (m *CommandGetSchemaResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetSchemaResponse) XXX_Merge

func (m *CommandGetSchemaResponse) XXX_Merge(src proto.Message)

func (*CommandGetSchemaResponse) XXX_Size

func (m *CommandGetSchemaResponse) XXX_Size() int

func (*CommandGetSchemaResponse) XXX_Unmarshal

func (m *CommandGetSchemaResponse) XXX_Unmarshal(b []byte) error

type CommandGetTopicsOfNamespace

type CommandGetTopicsOfNamespace struct {
	RequestId            *uint64                           `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Namespace            *string                           `protobuf:"bytes,2,req,name=namespace" json:"namespace,omitempty"`
	Mode                 *CommandGetTopicsOfNamespace_Mode `protobuf:"varint,3,opt,name=mode,enum=pulsar.proto.CommandGetTopicsOfNamespace_Mode,def=0" json:"mode,omitempty"`
	NetModel             *string                           `protobuf:"bytes,4,opt,name=net_model,json=netModel" json:"net_model,omitempty"`
	XXX_NoUnkeyedLiteral struct{}                          `json:"-"`
	XXX_unrecognized     []byte                            `json:"-"`
	XXX_sizecache        int32                             `json:"-"`
}

func (*CommandGetTopicsOfNamespace) Descriptor

func (*CommandGetTopicsOfNamespace) Descriptor() ([]byte, []int)

func (*CommandGetTopicsOfNamespace) GetMode

func (*CommandGetTopicsOfNamespace) GetNamespace

func (m *CommandGetTopicsOfNamespace) GetNamespace() string

func (*CommandGetTopicsOfNamespace) GetNetModel

func (m *CommandGetTopicsOfNamespace) GetNetModel() string

func (*CommandGetTopicsOfNamespace) GetRequestId

func (m *CommandGetTopicsOfNamespace) GetRequestId() uint64

func (*CommandGetTopicsOfNamespace) Marshal

func (m *CommandGetTopicsOfNamespace) Marshal() (dAtA []byte, err error)

func (*CommandGetTopicsOfNamespace) MarshalTo

func (m *CommandGetTopicsOfNamespace) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetTopicsOfNamespace) MarshalToSizedBuffer

func (m *CommandGetTopicsOfNamespace) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetTopicsOfNamespace) ProtoMessage

func (*CommandGetTopicsOfNamespace) ProtoMessage()

func (*CommandGetTopicsOfNamespace) Reset

func (m *CommandGetTopicsOfNamespace) Reset()

func (*CommandGetTopicsOfNamespace) Size

func (m *CommandGetTopicsOfNamespace) Size() (n int)

func (*CommandGetTopicsOfNamespace) String

func (m *CommandGetTopicsOfNamespace) String() string

func (*CommandGetTopicsOfNamespace) Unmarshal

func (m *CommandGetTopicsOfNamespace) Unmarshal(dAtA []byte) error

func (*CommandGetTopicsOfNamespace) XXX_DiscardUnknown

func (m *CommandGetTopicsOfNamespace) XXX_DiscardUnknown()

func (*CommandGetTopicsOfNamespace) XXX_Marshal

func (m *CommandGetTopicsOfNamespace) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetTopicsOfNamespace) XXX_Merge

func (m *CommandGetTopicsOfNamespace) XXX_Merge(src proto.Message)

func (*CommandGetTopicsOfNamespace) XXX_Size

func (m *CommandGetTopicsOfNamespace) XXX_Size() int

func (*CommandGetTopicsOfNamespace) XXX_Unmarshal

func (m *CommandGetTopicsOfNamespace) XXX_Unmarshal(b []byte) error

type CommandGetTopicsOfNamespaceResponse

type CommandGetTopicsOfNamespaceResponse struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Topics               []string `protobuf:"bytes,2,rep,name=topics" json:"topics,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandGetTopicsOfNamespaceResponse) Descriptor

func (*CommandGetTopicsOfNamespaceResponse) Descriptor() ([]byte, []int)

func (*CommandGetTopicsOfNamespaceResponse) GetRequestId

func (m *CommandGetTopicsOfNamespaceResponse) GetRequestId() uint64

func (*CommandGetTopicsOfNamespaceResponse) GetTopics

func (*CommandGetTopicsOfNamespaceResponse) Marshal

func (m *CommandGetTopicsOfNamespaceResponse) Marshal() (dAtA []byte, err error)

func (*CommandGetTopicsOfNamespaceResponse) MarshalTo

func (m *CommandGetTopicsOfNamespaceResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandGetTopicsOfNamespaceResponse) MarshalToSizedBuffer

func (m *CommandGetTopicsOfNamespaceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandGetTopicsOfNamespaceResponse) ProtoMessage

func (*CommandGetTopicsOfNamespaceResponse) ProtoMessage()

func (*CommandGetTopicsOfNamespaceResponse) Reset

func (*CommandGetTopicsOfNamespaceResponse) Size

func (*CommandGetTopicsOfNamespaceResponse) String

func (*CommandGetTopicsOfNamespaceResponse) Unmarshal

func (m *CommandGetTopicsOfNamespaceResponse) Unmarshal(dAtA []byte) error

func (*CommandGetTopicsOfNamespaceResponse) XXX_DiscardUnknown

func (m *CommandGetTopicsOfNamespaceResponse) XXX_DiscardUnknown()

func (*CommandGetTopicsOfNamespaceResponse) XXX_Marshal

func (m *CommandGetTopicsOfNamespaceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandGetTopicsOfNamespaceResponse) XXX_Merge

func (*CommandGetTopicsOfNamespaceResponse) XXX_Size

func (*CommandGetTopicsOfNamespaceResponse) XXX_Unmarshal

func (m *CommandGetTopicsOfNamespaceResponse) XXX_Unmarshal(b []byte) error

type CommandGetTopicsOfNamespace_Mode

type CommandGetTopicsOfNamespace_Mode int32
const (
	CommandGetTopicsOfNamespace_PERSISTENT     CommandGetTopicsOfNamespace_Mode = 0
	CommandGetTopicsOfNamespace_NON_PERSISTENT CommandGetTopicsOfNamespace_Mode = 1
	CommandGetTopicsOfNamespace_ALL            CommandGetTopicsOfNamespace_Mode = 2
)
const Default_CommandGetTopicsOfNamespace_Mode CommandGetTopicsOfNamespace_Mode = CommandGetTopicsOfNamespace_PERSISTENT

func (CommandGetTopicsOfNamespace_Mode) Enum

func (CommandGetTopicsOfNamespace_Mode) EnumDescriptor

func (CommandGetTopicsOfNamespace_Mode) EnumDescriptor() ([]byte, []int)

func (CommandGetTopicsOfNamespace_Mode) String

func (*CommandGetTopicsOfNamespace_Mode) UnmarshalJSON

func (x *CommandGetTopicsOfNamespace_Mode) UnmarshalJSON(data []byte) error

type CommandLookupTopic

type CommandLookupTopic struct {
	Topic         *string `protobuf:"bytes,1,req,name=topic" json:"topic,omitempty"`
	RequestId     *uint64 `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Authoritative *bool   `protobuf:"varint,3,opt,name=authoritative,def=0" json:"authoritative,omitempty"`
	// TODO - Remove original_principal, original_auth_data, original_auth_method
	// Original principal that was verified by
	// a Pulsar proxy.
	OriginalPrincipal *string `protobuf:"bytes,4,opt,name=original_principal,json=originalPrincipal" json:"original_principal,omitempty"`
	// Original auth role and auth Method that was passed
	// to the proxy.
	OriginalAuthData   *string `protobuf:"bytes,5,opt,name=original_auth_data,json=originalAuthData" json:"original_auth_data,omitempty"`
	OriginalAuthMethod *string `protobuf:"bytes,6,opt,name=original_auth_method,json=originalAuthMethod" json:"original_auth_method,omitempty"`
	// net mode setting
	NetModel             *string  `protobuf:"bytes,7,opt,name=net_model,json=netModel" json:"net_model,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandLookupTopic) Descriptor

func (*CommandLookupTopic) Descriptor() ([]byte, []int)

func (*CommandLookupTopic) GetAuthoritative

func (m *CommandLookupTopic) GetAuthoritative() bool

func (*CommandLookupTopic) GetNetModel

func (m *CommandLookupTopic) GetNetModel() string

func (*CommandLookupTopic) GetOriginalAuthData

func (m *CommandLookupTopic) GetOriginalAuthData() string

func (*CommandLookupTopic) GetOriginalAuthMethod

func (m *CommandLookupTopic) GetOriginalAuthMethod() string

func (*CommandLookupTopic) GetOriginalPrincipal

func (m *CommandLookupTopic) GetOriginalPrincipal() string

func (*CommandLookupTopic) GetRequestId

func (m *CommandLookupTopic) GetRequestId() uint64

func (*CommandLookupTopic) GetTopic

func (m *CommandLookupTopic) GetTopic() string

func (*CommandLookupTopic) Marshal

func (m *CommandLookupTopic) Marshal() (dAtA []byte, err error)

func (*CommandLookupTopic) MarshalTo

func (m *CommandLookupTopic) MarshalTo(dAtA []byte) (int, error)

func (*CommandLookupTopic) MarshalToSizedBuffer

func (m *CommandLookupTopic) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandLookupTopic) ProtoMessage

func (*CommandLookupTopic) ProtoMessage()

func (*CommandLookupTopic) Reset

func (m *CommandLookupTopic) Reset()

func (*CommandLookupTopic) Size

func (m *CommandLookupTopic) Size() (n int)

func (*CommandLookupTopic) String

func (m *CommandLookupTopic) String() string

func (*CommandLookupTopic) Unmarshal

func (m *CommandLookupTopic) Unmarshal(dAtA []byte) error

func (*CommandLookupTopic) XXX_DiscardUnknown

func (m *CommandLookupTopic) XXX_DiscardUnknown()

func (*CommandLookupTopic) XXX_Marshal

func (m *CommandLookupTopic) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandLookupTopic) XXX_Merge

func (m *CommandLookupTopic) XXX_Merge(src proto.Message)

func (*CommandLookupTopic) XXX_Size

func (m *CommandLookupTopic) XXX_Size() int

func (*CommandLookupTopic) XXX_Unmarshal

func (m *CommandLookupTopic) XXX_Unmarshal(b []byte) error

type CommandLookupTopicResponse

type CommandLookupTopicResponse struct {
	BrokerServiceUrl    *string                                `protobuf:"bytes,1,opt,name=brokerServiceUrl" json:"brokerServiceUrl,omitempty"`
	BrokerServiceUrlTls *string                                `protobuf:"bytes,2,opt,name=brokerServiceUrlTls" json:"brokerServiceUrlTls,omitempty"`
	Response            *CommandLookupTopicResponse_LookupType `protobuf:"varint,3,opt,name=response,enum=pulsar.proto.CommandLookupTopicResponse_LookupType" json:"response,omitempty"`
	RequestId           *uint64                                `protobuf:"varint,4,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Authoritative       *bool                                  `protobuf:"varint,5,opt,name=authoritative,def=0" json:"authoritative,omitempty"`
	Error               *ServerError                           `protobuf:"varint,6,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message             *string                                `protobuf:"bytes,7,opt,name=message" json:"message,omitempty"`
	// If it's true, indicates to the client that it must
	// always connect through the service url after the
	// lookup has been completed.
	ProxyThroughServiceUrl *bool    `` /* 131-byte string literal not displayed */
	XXX_NoUnkeyedLiteral   struct{} `json:"-"`
	XXX_unrecognized       []byte   `json:"-"`
	XXX_sizecache          int32    `json:"-"`
}

func (*CommandLookupTopicResponse) Descriptor

func (*CommandLookupTopicResponse) Descriptor() ([]byte, []int)

func (*CommandLookupTopicResponse) GetAuthoritative

func (m *CommandLookupTopicResponse) GetAuthoritative() bool

func (*CommandLookupTopicResponse) GetBrokerServiceUrl

func (m *CommandLookupTopicResponse) GetBrokerServiceUrl() string

func (*CommandLookupTopicResponse) GetBrokerServiceUrlTls

func (m *CommandLookupTopicResponse) GetBrokerServiceUrlTls() string

func (*CommandLookupTopicResponse) GetError

func (*CommandLookupTopicResponse) GetMessage

func (m *CommandLookupTopicResponse) GetMessage() string

func (*CommandLookupTopicResponse) GetProxyThroughServiceUrl

func (m *CommandLookupTopicResponse) GetProxyThroughServiceUrl() bool

func (*CommandLookupTopicResponse) GetRequestId

func (m *CommandLookupTopicResponse) GetRequestId() uint64

func (*CommandLookupTopicResponse) GetResponse

func (*CommandLookupTopicResponse) Marshal

func (m *CommandLookupTopicResponse) Marshal() (dAtA []byte, err error)

func (*CommandLookupTopicResponse) MarshalTo

func (m *CommandLookupTopicResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandLookupTopicResponse) MarshalToSizedBuffer

func (m *CommandLookupTopicResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandLookupTopicResponse) ProtoMessage

func (*CommandLookupTopicResponse) ProtoMessage()

func (*CommandLookupTopicResponse) Reset

func (m *CommandLookupTopicResponse) Reset()

func (*CommandLookupTopicResponse) Size

func (m *CommandLookupTopicResponse) Size() (n int)

func (*CommandLookupTopicResponse) String

func (m *CommandLookupTopicResponse) String() string

func (*CommandLookupTopicResponse) Unmarshal

func (m *CommandLookupTopicResponse) Unmarshal(dAtA []byte) error

func (*CommandLookupTopicResponse) XXX_DiscardUnknown

func (m *CommandLookupTopicResponse) XXX_DiscardUnknown()

func (*CommandLookupTopicResponse) XXX_Marshal

func (m *CommandLookupTopicResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandLookupTopicResponse) XXX_Merge

func (m *CommandLookupTopicResponse) XXX_Merge(src proto.Message)

func (*CommandLookupTopicResponse) XXX_Size

func (m *CommandLookupTopicResponse) XXX_Size() int

func (*CommandLookupTopicResponse) XXX_Unmarshal

func (m *CommandLookupTopicResponse) XXX_Unmarshal(b []byte) error

type CommandLookupTopicResponse_LookupType

type CommandLookupTopicResponse_LookupType int32
const (
	CommandLookupTopicResponse_Redirect CommandLookupTopicResponse_LookupType = 0
	CommandLookupTopicResponse_Connect  CommandLookupTopicResponse_LookupType = 1
	CommandLookupTopicResponse_Failed   CommandLookupTopicResponse_LookupType = 2
)

func (CommandLookupTopicResponse_LookupType) Enum

func (CommandLookupTopicResponse_LookupType) EnumDescriptor

func (CommandLookupTopicResponse_LookupType) EnumDescriptor() ([]byte, []int)

func (CommandLookupTopicResponse_LookupType) String

func (*CommandLookupTopicResponse_LookupType) UnmarshalJSON

func (x *CommandLookupTopicResponse_LookupType) UnmarshalJSON(data []byte) error

type CommandMessage

type CommandMessage struct {
	ConsumerId           *uint64        `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	MessageId            *MessageIdData `protobuf:"bytes,2,req,name=message_id,json=messageId" json:"message_id,omitempty"`
	RedeliveryCount      *uint32        `protobuf:"varint,3,opt,name=redelivery_count,json=redeliveryCount,def=0" json:"redelivery_count,omitempty"`
	XXX_NoUnkeyedLiteral struct{}       `json:"-"`
	XXX_unrecognized     []byte         `json:"-"`
	XXX_sizecache        int32          `json:"-"`
}

func (*CommandMessage) Descriptor

func (*CommandMessage) Descriptor() ([]byte, []int)

func (*CommandMessage) GetConsumerId

func (m *CommandMessage) GetConsumerId() uint64

func (*CommandMessage) GetMessageId

func (m *CommandMessage) GetMessageId() *MessageIdData

func (*CommandMessage) GetRedeliveryCount

func (m *CommandMessage) GetRedeliveryCount() uint32

func (*CommandMessage) Marshal

func (m *CommandMessage) Marshal() (dAtA []byte, err error)

func (*CommandMessage) MarshalTo

func (m *CommandMessage) MarshalTo(dAtA []byte) (int, error)

func (*CommandMessage) MarshalToSizedBuffer

func (m *CommandMessage) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandMessage) ProtoMessage

func (*CommandMessage) ProtoMessage()

func (*CommandMessage) Reset

func (m *CommandMessage) Reset()

func (*CommandMessage) Size

func (m *CommandMessage) Size() (n int)

func (*CommandMessage) String

func (m *CommandMessage) String() string

func (*CommandMessage) Unmarshal

func (m *CommandMessage) Unmarshal(dAtA []byte) error

func (*CommandMessage) XXX_DiscardUnknown

func (m *CommandMessage) XXX_DiscardUnknown()

func (*CommandMessage) XXX_Marshal

func (m *CommandMessage) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandMessage) XXX_Merge

func (m *CommandMessage) XXX_Merge(src proto.Message)

func (*CommandMessage) XXX_Size

func (m *CommandMessage) XXX_Size() int

func (*CommandMessage) XXX_Unmarshal

func (m *CommandMessage) XXX_Unmarshal(b []byte) error

type CommandNewTxn

type CommandNewTxn struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnTtlSeconds        *uint64  `protobuf:"varint,2,opt,name=txn_ttl_seconds,json=txnTtlSeconds,def=0" json:"txn_ttl_seconds,omitempty"`
	TcId                 *uint64  `protobuf:"varint,3,opt,name=tc_id,json=tcId,def=0" json:"tc_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandNewTxn) Descriptor

func (*CommandNewTxn) Descriptor() ([]byte, []int)

func (*CommandNewTxn) GetRequestId

func (m *CommandNewTxn) GetRequestId() uint64

func (*CommandNewTxn) GetTcId

func (m *CommandNewTxn) GetTcId() uint64

func (*CommandNewTxn) GetTxnTtlSeconds

func (m *CommandNewTxn) GetTxnTtlSeconds() uint64

func (*CommandNewTxn) Marshal

func (m *CommandNewTxn) Marshal() (dAtA []byte, err error)

func (*CommandNewTxn) MarshalTo

func (m *CommandNewTxn) MarshalTo(dAtA []byte) (int, error)

func (*CommandNewTxn) MarshalToSizedBuffer

func (m *CommandNewTxn) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandNewTxn) ProtoMessage

func (*CommandNewTxn) ProtoMessage()

func (*CommandNewTxn) Reset

func (m *CommandNewTxn) Reset()

func (*CommandNewTxn) Size

func (m *CommandNewTxn) Size() (n int)

func (*CommandNewTxn) String

func (m *CommandNewTxn) String() string

func (*CommandNewTxn) Unmarshal

func (m *CommandNewTxn) Unmarshal(dAtA []byte) error

func (*CommandNewTxn) XXX_DiscardUnknown

func (m *CommandNewTxn) XXX_DiscardUnknown()

func (*CommandNewTxn) XXX_Marshal

func (m *CommandNewTxn) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandNewTxn) XXX_Merge

func (m *CommandNewTxn) XXX_Merge(src proto.Message)

func (*CommandNewTxn) XXX_Size

func (m *CommandNewTxn) XXX_Size() int

func (*CommandNewTxn) XXX_Unmarshal

func (m *CommandNewTxn) XXX_Unmarshal(b []byte) error

type CommandNewTxnResponse

type CommandNewTxnResponse struct {
	RequestId            *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TxnidLeastBits       *uint64      `protobuf:"varint,2,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits        *uint64      `protobuf:"varint,3,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	Error                *ServerError `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandNewTxnResponse) Descriptor

func (*CommandNewTxnResponse) Descriptor() ([]byte, []int)

func (*CommandNewTxnResponse) GetError

func (m *CommandNewTxnResponse) GetError() ServerError

func (*CommandNewTxnResponse) GetMessage

func (m *CommandNewTxnResponse) GetMessage() string

func (*CommandNewTxnResponse) GetRequestId

func (m *CommandNewTxnResponse) GetRequestId() uint64

func (*CommandNewTxnResponse) GetTxnidLeastBits

func (m *CommandNewTxnResponse) GetTxnidLeastBits() uint64

func (*CommandNewTxnResponse) GetTxnidMostBits

func (m *CommandNewTxnResponse) GetTxnidMostBits() uint64

func (*CommandNewTxnResponse) Marshal

func (m *CommandNewTxnResponse) Marshal() (dAtA []byte, err error)

func (*CommandNewTxnResponse) MarshalTo

func (m *CommandNewTxnResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandNewTxnResponse) MarshalToSizedBuffer

func (m *CommandNewTxnResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandNewTxnResponse) ProtoMessage

func (*CommandNewTxnResponse) ProtoMessage()

func (*CommandNewTxnResponse) Reset

func (m *CommandNewTxnResponse) Reset()

func (*CommandNewTxnResponse) Size

func (m *CommandNewTxnResponse) Size() (n int)

func (*CommandNewTxnResponse) String

func (m *CommandNewTxnResponse) String() string

func (*CommandNewTxnResponse) Unmarshal

func (m *CommandNewTxnResponse) Unmarshal(dAtA []byte) error

func (*CommandNewTxnResponse) XXX_DiscardUnknown

func (m *CommandNewTxnResponse) XXX_DiscardUnknown()

func (*CommandNewTxnResponse) XXX_Marshal

func (m *CommandNewTxnResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandNewTxnResponse) XXX_Merge

func (m *CommandNewTxnResponse) XXX_Merge(src proto.Message)

func (*CommandNewTxnResponse) XXX_Size

func (m *CommandNewTxnResponse) XXX_Size() int

func (*CommandNewTxnResponse) XXX_Unmarshal

func (m *CommandNewTxnResponse) XXX_Unmarshal(b []byte) error

type CommandPartitionedTopicMetadata

type CommandPartitionedTopicMetadata struct {
	Topic     *string `protobuf:"bytes,1,req,name=topic" json:"topic,omitempty"`
	RequestId *uint64 `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	// TODO - Remove original_principal, original_auth_data, original_auth_method
	// Original principal that was verified by
	// a Pulsar proxy.
	OriginalPrincipal *string `protobuf:"bytes,3,opt,name=original_principal,json=originalPrincipal" json:"original_principal,omitempty"`
	// Original auth role and auth Method that was passed
	// to the proxy.
	OriginalAuthData     *string  `protobuf:"bytes,4,opt,name=original_auth_data,json=originalAuthData" json:"original_auth_data,omitempty"`
	OriginalAuthMethod   *string  `protobuf:"bytes,5,opt,name=original_auth_method,json=originalAuthMethod" json:"original_auth_method,omitempty"`
	NetModel             *string  `protobuf:"bytes,6,opt,name=net_model,json=netModel" json:"net_model,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandPartitionedTopicMetadata) Descriptor

func (*CommandPartitionedTopicMetadata) Descriptor() ([]byte, []int)

func (*CommandPartitionedTopicMetadata) GetNetModel

func (m *CommandPartitionedTopicMetadata) GetNetModel() string

func (*CommandPartitionedTopicMetadata) GetOriginalAuthData

func (m *CommandPartitionedTopicMetadata) GetOriginalAuthData() string

func (*CommandPartitionedTopicMetadata) GetOriginalAuthMethod

func (m *CommandPartitionedTopicMetadata) GetOriginalAuthMethod() string

func (*CommandPartitionedTopicMetadata) GetOriginalPrincipal

func (m *CommandPartitionedTopicMetadata) GetOriginalPrincipal() string

func (*CommandPartitionedTopicMetadata) GetRequestId

func (m *CommandPartitionedTopicMetadata) GetRequestId() uint64

func (*CommandPartitionedTopicMetadata) GetTopic

func (*CommandPartitionedTopicMetadata) Marshal

func (m *CommandPartitionedTopicMetadata) Marshal() (dAtA []byte, err error)

func (*CommandPartitionedTopicMetadata) MarshalTo

func (m *CommandPartitionedTopicMetadata) MarshalTo(dAtA []byte) (int, error)

func (*CommandPartitionedTopicMetadata) MarshalToSizedBuffer

func (m *CommandPartitionedTopicMetadata) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandPartitionedTopicMetadata) ProtoMessage

func (*CommandPartitionedTopicMetadata) ProtoMessage()

func (*CommandPartitionedTopicMetadata) Reset

func (*CommandPartitionedTopicMetadata) Size

func (m *CommandPartitionedTopicMetadata) Size() (n int)

func (*CommandPartitionedTopicMetadata) String

func (*CommandPartitionedTopicMetadata) Unmarshal

func (m *CommandPartitionedTopicMetadata) Unmarshal(dAtA []byte) error

func (*CommandPartitionedTopicMetadata) XXX_DiscardUnknown

func (m *CommandPartitionedTopicMetadata) XXX_DiscardUnknown()

func (*CommandPartitionedTopicMetadata) XXX_Marshal

func (m *CommandPartitionedTopicMetadata) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandPartitionedTopicMetadata) XXX_Merge

func (m *CommandPartitionedTopicMetadata) XXX_Merge(src proto.Message)

func (*CommandPartitionedTopicMetadata) XXX_Size

func (m *CommandPartitionedTopicMetadata) XXX_Size() int

func (*CommandPartitionedTopicMetadata) XXX_Unmarshal

func (m *CommandPartitionedTopicMetadata) XXX_Unmarshal(b []byte) error

type CommandPartitionedTopicMetadataResponse

type CommandPartitionedTopicMetadataResponse struct {
	Partitions           *uint32                                             `protobuf:"varint,1,opt,name=partitions" json:"partitions,omitempty"`
	RequestId            *uint64                                             `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Response             *CommandPartitionedTopicMetadataResponse_LookupType `` /* 132-byte string literal not displayed */
	Error                *ServerError                                        `protobuf:"varint,4,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string                                             `protobuf:"bytes,5,opt,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}                                            `json:"-"`
	XXX_unrecognized     []byte                                              `json:"-"`
	XXX_sizecache        int32                                               `json:"-"`
}

func (*CommandPartitionedTopicMetadataResponse) Descriptor

func (*CommandPartitionedTopicMetadataResponse) Descriptor() ([]byte, []int)

func (*CommandPartitionedTopicMetadataResponse) GetError

func (*CommandPartitionedTopicMetadataResponse) GetMessage

func (*CommandPartitionedTopicMetadataResponse) GetPartitions

func (*CommandPartitionedTopicMetadataResponse) GetRequestId

func (*CommandPartitionedTopicMetadataResponse) GetResponse

func (*CommandPartitionedTopicMetadataResponse) Marshal

func (m *CommandPartitionedTopicMetadataResponse) Marshal() (dAtA []byte, err error)

func (*CommandPartitionedTopicMetadataResponse) MarshalTo

func (m *CommandPartitionedTopicMetadataResponse) MarshalTo(dAtA []byte) (int, error)

func (*CommandPartitionedTopicMetadataResponse) MarshalToSizedBuffer

func (m *CommandPartitionedTopicMetadataResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandPartitionedTopicMetadataResponse) ProtoMessage

func (*CommandPartitionedTopicMetadataResponse) Reset

func (*CommandPartitionedTopicMetadataResponse) Size

func (*CommandPartitionedTopicMetadataResponse) String

func (*CommandPartitionedTopicMetadataResponse) Unmarshal

func (m *CommandPartitionedTopicMetadataResponse) Unmarshal(dAtA []byte) error

func (*CommandPartitionedTopicMetadataResponse) XXX_DiscardUnknown

func (m *CommandPartitionedTopicMetadataResponse) XXX_DiscardUnknown()

func (*CommandPartitionedTopicMetadataResponse) XXX_Marshal

func (m *CommandPartitionedTopicMetadataResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandPartitionedTopicMetadataResponse) XXX_Merge

func (*CommandPartitionedTopicMetadataResponse) XXX_Size

func (*CommandPartitionedTopicMetadataResponse) XXX_Unmarshal

func (m *CommandPartitionedTopicMetadataResponse) XXX_Unmarshal(b []byte) error

type CommandPartitionedTopicMetadataResponse_LookupType

type CommandPartitionedTopicMetadataResponse_LookupType int32
const (
	CommandPartitionedTopicMetadataResponse_Success CommandPartitionedTopicMetadataResponse_LookupType = 0
	CommandPartitionedTopicMetadataResponse_Failed  CommandPartitionedTopicMetadataResponse_LookupType = 1
)

func (CommandPartitionedTopicMetadataResponse_LookupType) Enum

func (CommandPartitionedTopicMetadataResponse_LookupType) EnumDescriptor

func (CommandPartitionedTopicMetadataResponse_LookupType) String

func (*CommandPartitionedTopicMetadataResponse_LookupType) UnmarshalJSON

type CommandPing

type CommandPing struct {
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

Commands to probe the state of connection. When either client or broker doesn't receive commands for certain amount of time, they will send a Ping probe.

func (*CommandPing) Descriptor

func (*CommandPing) Descriptor() ([]byte, []int)

func (*CommandPing) Marshal

func (m *CommandPing) Marshal() (dAtA []byte, err error)

func (*CommandPing) MarshalTo

func (m *CommandPing) MarshalTo(dAtA []byte) (int, error)

func (*CommandPing) MarshalToSizedBuffer

func (m *CommandPing) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandPing) ProtoMessage

func (*CommandPing) ProtoMessage()

func (*CommandPing) Reset

func (m *CommandPing) Reset()

func (*CommandPing) Size

func (m *CommandPing) Size() (n int)

func (*CommandPing) String

func (m *CommandPing) String() string

func (*CommandPing) Unmarshal

func (m *CommandPing) Unmarshal(dAtA []byte) error

func (*CommandPing) XXX_DiscardUnknown

func (m *CommandPing) XXX_DiscardUnknown()

func (*CommandPing) XXX_Marshal

func (m *CommandPing) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandPing) XXX_Merge

func (m *CommandPing) XXX_Merge(src proto.Message)

func (*CommandPing) XXX_Size

func (m *CommandPing) XXX_Size() int

func (*CommandPing) XXX_Unmarshal

func (m *CommandPing) XXX_Unmarshal(b []byte) error

type CommandPong

type CommandPong struct {
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandPong) Descriptor

func (*CommandPong) Descriptor() ([]byte, []int)

func (*CommandPong) Marshal

func (m *CommandPong) Marshal() (dAtA []byte, err error)

func (*CommandPong) MarshalTo

func (m *CommandPong) MarshalTo(dAtA []byte) (int, error)

func (*CommandPong) MarshalToSizedBuffer

func (m *CommandPong) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandPong) ProtoMessage

func (*CommandPong) ProtoMessage()

func (*CommandPong) Reset

func (m *CommandPong) Reset()

func (*CommandPong) Size

func (m *CommandPong) Size() (n int)

func (*CommandPong) String

func (m *CommandPong) String() string

func (*CommandPong) Unmarshal

func (m *CommandPong) Unmarshal(dAtA []byte) error

func (*CommandPong) XXX_DiscardUnknown

func (m *CommandPong) XXX_DiscardUnknown()

func (*CommandPong) XXX_Marshal

func (m *CommandPong) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandPong) XXX_Merge

func (m *CommandPong) XXX_Merge(src proto.Message)

func (*CommandPong) XXX_Size

func (m *CommandPong) XXX_Size() int

func (*CommandPong) XXX_Unmarshal

func (m *CommandPong) XXX_Unmarshal(b []byte) error

type CommandProducer

type CommandProducer struct {
	Topic      *string `protobuf:"bytes,1,req,name=topic" json:"topic,omitempty"`
	ProducerId *uint64 `protobuf:"varint,2,req,name=producer_id,json=producerId" json:"producer_id,omitempty"`
	RequestId  *uint64 `protobuf:"varint,3,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	/// If a producer name is specified, the name will be used,
	/// otherwise the broker will generate a unique name
	ProducerName *string `protobuf:"bytes,4,opt,name=producer_name,json=producerName" json:"producer_name,omitempty"`
	Encrypted    *bool   `protobuf:"varint,5,opt,name=encrypted,def=0" json:"encrypted,omitempty"`
	/// Add optional metadata key=value to this producer
	Metadata []*KeyValue `protobuf:"bytes,6,rep,name=metadata" json:"metadata,omitempty"`
	Schema   *Schema     `protobuf:"bytes,7,opt,name=schema" json:"schema,omitempty"`
	// If producer reconnect to broker, the epoch of this producer will +1
	Epoch *uint64 `protobuf:"varint,8,opt,name=epoch,def=0" json:"epoch,omitempty"`
	// Indicate the name of the producer is generated or user provided
	// Use default true here is in order to be forward compatible with the client
	UserProvidedProducerName *bool    `` /* 137-byte string literal not displayed */
	XXX_NoUnkeyedLiteral     struct{} `json:"-"`
	XXX_unrecognized         []byte   `json:"-"`
	XXX_sizecache            int32    `json:"-"`
}

/ Create a new Producer on a topic, assigning the given producer_id, / all messages sent with this producer_id will be persisted on the topic

func (*CommandProducer) Descriptor

func (*CommandProducer) Descriptor() ([]byte, []int)

func (*CommandProducer) GetEncrypted

func (m *CommandProducer) GetEncrypted() bool

func (*CommandProducer) GetEpoch

func (m *CommandProducer) GetEpoch() uint64

func (*CommandProducer) GetMetadata

func (m *CommandProducer) GetMetadata() []*KeyValue

func (*CommandProducer) GetProducerId

func (m *CommandProducer) GetProducerId() uint64

func (*CommandProducer) GetProducerName

func (m *CommandProducer) GetProducerName() string

func (*CommandProducer) GetRequestId

func (m *CommandProducer) GetRequestId() uint64

func (*CommandProducer) GetSchema

func (m *CommandProducer) GetSchema() *Schema

func (*CommandProducer) GetTopic

func (m *CommandProducer) GetTopic() string

func (*CommandProducer) GetUserProvidedProducerName

func (m *CommandProducer) GetUserProvidedProducerName() bool

func (*CommandProducer) Marshal

func (m *CommandProducer) Marshal() (dAtA []byte, err error)

func (*CommandProducer) MarshalTo

func (m *CommandProducer) MarshalTo(dAtA []byte) (int, error)

func (*CommandProducer) MarshalToSizedBuffer

func (m *CommandProducer) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandProducer) ProtoMessage

func (*CommandProducer) ProtoMessage()

func (*CommandProducer) Reset

func (m *CommandProducer) Reset()

func (*CommandProducer) Size

func (m *CommandProducer) Size() (n int)

func (*CommandProducer) String

func (m *CommandProducer) String() string

func (*CommandProducer) Unmarshal

func (m *CommandProducer) Unmarshal(dAtA []byte) error

func (*CommandProducer) XXX_DiscardUnknown

func (m *CommandProducer) XXX_DiscardUnknown()

func (*CommandProducer) XXX_Marshal

func (m *CommandProducer) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandProducer) XXX_Merge

func (m *CommandProducer) XXX_Merge(src proto.Message)

func (*CommandProducer) XXX_Size

func (m *CommandProducer) XXX_Size() int

func (*CommandProducer) XXX_Unmarshal

func (m *CommandProducer) XXX_Unmarshal(b []byte) error

type CommandProducerSuccess

type CommandProducerSuccess struct {
	RequestId    *uint64 `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	ProducerName *string `protobuf:"bytes,2,req,name=producer_name,json=producerName" json:"producer_name,omitempty"`
	// The last sequence id that was stored by this producer in the previous session
	// This will only be meaningful if deduplication has been enabled.
	LastSequenceId       *int64   `protobuf:"varint,3,opt,name=last_sequence_id,json=lastSequenceId,def=-1" json:"last_sequence_id,omitempty"`
	SchemaVersion        []byte   `protobuf:"bytes,4,opt,name=schema_version,json=schemaVersion" json:"schema_version,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

/ Response from CommandProducer

func (*CommandProducerSuccess) Descriptor

func (*CommandProducerSuccess) Descriptor() ([]byte, []int)

func (*CommandProducerSuccess) GetLastSequenceId

func (m *CommandProducerSuccess) GetLastSequenceId() int64

func (*CommandProducerSuccess) GetProducerName

func (m *CommandProducerSuccess) GetProducerName() string

func (*CommandProducerSuccess) GetRequestId

func (m *CommandProducerSuccess) GetRequestId() uint64

func (*CommandProducerSuccess) GetSchemaVersion

func (m *CommandProducerSuccess) GetSchemaVersion() []byte

func (*CommandProducerSuccess) Marshal

func (m *CommandProducerSuccess) Marshal() (dAtA []byte, err error)

func (*CommandProducerSuccess) MarshalTo

func (m *CommandProducerSuccess) MarshalTo(dAtA []byte) (int, error)

func (*CommandProducerSuccess) MarshalToSizedBuffer

func (m *CommandProducerSuccess) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandProducerSuccess) ProtoMessage

func (*CommandProducerSuccess) ProtoMessage()

func (*CommandProducerSuccess) Reset

func (m *CommandProducerSuccess) Reset()

func (*CommandProducerSuccess) Size

func (m *CommandProducerSuccess) Size() (n int)

func (*CommandProducerSuccess) String

func (m *CommandProducerSuccess) String() string

func (*CommandProducerSuccess) Unmarshal

func (m *CommandProducerSuccess) Unmarshal(dAtA []byte) error

func (*CommandProducerSuccess) XXX_DiscardUnknown

func (m *CommandProducerSuccess) XXX_DiscardUnknown()

func (*CommandProducerSuccess) XXX_Marshal

func (m *CommandProducerSuccess) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandProducerSuccess) XXX_Merge

func (m *CommandProducerSuccess) XXX_Merge(src proto.Message)

func (*CommandProducerSuccess) XXX_Size

func (m *CommandProducerSuccess) XXX_Size() int

func (*CommandProducerSuccess) XXX_Unmarshal

func (m *CommandProducerSuccess) XXX_Unmarshal(b []byte) error

type CommandReachedEndOfTopic

type CommandReachedEndOfTopic struct {
	ConsumerId           *uint64  `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

Message sent by broker to client when a topic has been forcefully terminated and there are no more messages left to consume

func (*CommandReachedEndOfTopic) Descriptor

func (*CommandReachedEndOfTopic) Descriptor() ([]byte, []int)

func (*CommandReachedEndOfTopic) GetConsumerId

func (m *CommandReachedEndOfTopic) GetConsumerId() uint64

func (*CommandReachedEndOfTopic) Marshal

func (m *CommandReachedEndOfTopic) Marshal() (dAtA []byte, err error)

func (*CommandReachedEndOfTopic) MarshalTo

func (m *CommandReachedEndOfTopic) MarshalTo(dAtA []byte) (int, error)

func (*CommandReachedEndOfTopic) MarshalToSizedBuffer

func (m *CommandReachedEndOfTopic) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandReachedEndOfTopic) ProtoMessage

func (*CommandReachedEndOfTopic) ProtoMessage()

func (*CommandReachedEndOfTopic) Reset

func (m *CommandReachedEndOfTopic) Reset()

func (*CommandReachedEndOfTopic) Size

func (m *CommandReachedEndOfTopic) Size() (n int)

func (*CommandReachedEndOfTopic) String

func (m *CommandReachedEndOfTopic) String() string

func (*CommandReachedEndOfTopic) Unmarshal

func (m *CommandReachedEndOfTopic) Unmarshal(dAtA []byte) error

func (*CommandReachedEndOfTopic) XXX_DiscardUnknown

func (m *CommandReachedEndOfTopic) XXX_DiscardUnknown()

func (*CommandReachedEndOfTopic) XXX_Marshal

func (m *CommandReachedEndOfTopic) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandReachedEndOfTopic) XXX_Merge

func (m *CommandReachedEndOfTopic) XXX_Merge(src proto.Message)

func (*CommandReachedEndOfTopic) XXX_Size

func (m *CommandReachedEndOfTopic) XXX_Size() int

func (*CommandReachedEndOfTopic) XXX_Unmarshal

func (m *CommandReachedEndOfTopic) XXX_Unmarshal(b []byte) error

type CommandRedeliverUnacknowledgedMessages

type CommandRedeliverUnacknowledgedMessages struct {
	ConsumerId           *uint64          `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	MessageIds           []*MessageIdData `protobuf:"bytes,2,rep,name=message_ids,json=messageIds" json:"message_ids,omitempty"`
	XXX_NoUnkeyedLiteral struct{}         `json:"-"`
	XXX_unrecognized     []byte           `json:"-"`
	XXX_sizecache        int32            `json:"-"`
}

func (*CommandRedeliverUnacknowledgedMessages) Descriptor

func (*CommandRedeliverUnacknowledgedMessages) Descriptor() ([]byte, []int)

func (*CommandRedeliverUnacknowledgedMessages) GetConsumerId

func (*CommandRedeliverUnacknowledgedMessages) GetMessageIds

func (*CommandRedeliverUnacknowledgedMessages) Marshal

func (m *CommandRedeliverUnacknowledgedMessages) Marshal() (dAtA []byte, err error)

func (*CommandRedeliverUnacknowledgedMessages) MarshalTo

func (m *CommandRedeliverUnacknowledgedMessages) MarshalTo(dAtA []byte) (int, error)

func (*CommandRedeliverUnacknowledgedMessages) MarshalToSizedBuffer

func (m *CommandRedeliverUnacknowledgedMessages) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandRedeliverUnacknowledgedMessages) ProtoMessage

func (*CommandRedeliverUnacknowledgedMessages) Reset

func (*CommandRedeliverUnacknowledgedMessages) Size

func (*CommandRedeliverUnacknowledgedMessages) String

func (*CommandRedeliverUnacknowledgedMessages) Unmarshal

func (m *CommandRedeliverUnacknowledgedMessages) Unmarshal(dAtA []byte) error

func (*CommandRedeliverUnacknowledgedMessages) XXX_DiscardUnknown

func (m *CommandRedeliverUnacknowledgedMessages) XXX_DiscardUnknown()

func (*CommandRedeliverUnacknowledgedMessages) XXX_Marshal

func (m *CommandRedeliverUnacknowledgedMessages) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandRedeliverUnacknowledgedMessages) XXX_Merge

func (*CommandRedeliverUnacknowledgedMessages) XXX_Size

func (*CommandRedeliverUnacknowledgedMessages) XXX_Unmarshal

func (m *CommandRedeliverUnacknowledgedMessages) XXX_Unmarshal(b []byte) error

type CommandSeek

type CommandSeek struct {
	ConsumerId           *uint64        `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	RequestId            *uint64        `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	MessageId            *MessageIdData `protobuf:"bytes,3,opt,name=message_id,json=messageId" json:"message_id,omitempty"`
	MessagePublishTime   *uint64        `protobuf:"varint,4,opt,name=message_publish_time,json=messagePublishTime" json:"message_publish_time,omitempty"`
	XXX_NoUnkeyedLiteral struct{}       `json:"-"`
	XXX_unrecognized     []byte         `json:"-"`
	XXX_sizecache        int32          `json:"-"`
}

Reset an existing consumer to a particular message id

func (*CommandSeek) Descriptor

func (*CommandSeek) Descriptor() ([]byte, []int)

func (*CommandSeek) GetConsumerId

func (m *CommandSeek) GetConsumerId() uint64

func (*CommandSeek) GetMessageId

func (m *CommandSeek) GetMessageId() *MessageIdData

func (*CommandSeek) GetMessagePublishTime

func (m *CommandSeek) GetMessagePublishTime() uint64

func (*CommandSeek) GetRequestId

func (m *CommandSeek) GetRequestId() uint64

func (*CommandSeek) Marshal

func (m *CommandSeek) Marshal() (dAtA []byte, err error)

func (*CommandSeek) MarshalTo

func (m *CommandSeek) MarshalTo(dAtA []byte) (int, error)

func (*CommandSeek) MarshalToSizedBuffer

func (m *CommandSeek) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSeek) ProtoMessage

func (*CommandSeek) ProtoMessage()

func (*CommandSeek) Reset

func (m *CommandSeek) Reset()

func (*CommandSeek) Size

func (m *CommandSeek) Size() (n int)

func (*CommandSeek) String

func (m *CommandSeek) String() string

func (*CommandSeek) Unmarshal

func (m *CommandSeek) Unmarshal(dAtA []byte) error

func (*CommandSeek) XXX_DiscardUnknown

func (m *CommandSeek) XXX_DiscardUnknown()

func (*CommandSeek) XXX_Marshal

func (m *CommandSeek) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSeek) XXX_Merge

func (m *CommandSeek) XXX_Merge(src proto.Message)

func (*CommandSeek) XXX_Size

func (m *CommandSeek) XXX_Size() int

func (*CommandSeek) XXX_Unmarshal

func (m *CommandSeek) XXX_Unmarshal(b []byte) error

type CommandSend

type CommandSend struct {
	ProducerId     *uint64 `protobuf:"varint,1,req,name=producer_id,json=producerId" json:"producer_id,omitempty"`
	SequenceId     *uint64 `protobuf:"varint,2,req,name=sequence_id,json=sequenceId" json:"sequence_id,omitempty"`
	NumMessages    *int32  `protobuf:"varint,3,opt,name=num_messages,json=numMessages,def=1" json:"num_messages,omitempty"`
	TxnidLeastBits *uint64 `protobuf:"varint,4,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits  *uint64 `protobuf:"varint,5,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	/// Add highest sequence id to support batch message with external sequence id
	HighestSequenceId    *uint64  `protobuf:"varint,6,opt,name=highest_sequence_id,json=highestSequenceId,def=0" json:"highest_sequence_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandSend) Descriptor

func (*CommandSend) Descriptor() ([]byte, []int)

func (*CommandSend) GetHighestSequenceId

func (m *CommandSend) GetHighestSequenceId() uint64

func (*CommandSend) GetNumMessages

func (m *CommandSend) GetNumMessages() int32

func (*CommandSend) GetProducerId

func (m *CommandSend) GetProducerId() uint64

func (*CommandSend) GetSequenceId

func (m *CommandSend) GetSequenceId() uint64

func (*CommandSend) GetTxnidLeastBits

func (m *CommandSend) GetTxnidLeastBits() uint64

func (*CommandSend) GetTxnidMostBits

func (m *CommandSend) GetTxnidMostBits() uint64

func (*CommandSend) Marshal

func (m *CommandSend) Marshal() (dAtA []byte, err error)

func (*CommandSend) MarshalTo

func (m *CommandSend) MarshalTo(dAtA []byte) (int, error)

func (*CommandSend) MarshalToSizedBuffer

func (m *CommandSend) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSend) ProtoMessage

func (*CommandSend) ProtoMessage()

func (*CommandSend) Reset

func (m *CommandSend) Reset()

func (*CommandSend) Size

func (m *CommandSend) Size() (n int)

func (*CommandSend) String

func (m *CommandSend) String() string

func (*CommandSend) Unmarshal

func (m *CommandSend) Unmarshal(dAtA []byte) error

func (*CommandSend) XXX_DiscardUnknown

func (m *CommandSend) XXX_DiscardUnknown()

func (*CommandSend) XXX_Marshal

func (m *CommandSend) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSend) XXX_Merge

func (m *CommandSend) XXX_Merge(src proto.Message)

func (*CommandSend) XXX_Size

func (m *CommandSend) XXX_Size() int

func (*CommandSend) XXX_Unmarshal

func (m *CommandSend) XXX_Unmarshal(b []byte) error

type CommandSendError

type CommandSendError struct {
	ProducerId           *uint64      `protobuf:"varint,1,req,name=producer_id,json=producerId" json:"producer_id,omitempty"`
	SequenceId           *uint64      `protobuf:"varint,2,req,name=sequence_id,json=sequenceId" json:"sequence_id,omitempty"`
	Error                *ServerError `protobuf:"varint,3,req,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message              *string      `protobuf:"bytes,4,req,name=message" json:"message,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*CommandSendError) Descriptor

func (*CommandSendError) Descriptor() ([]byte, []int)

func (*CommandSendError) GetError

func (m *CommandSendError) GetError() ServerError

func (*CommandSendError) GetMessage

func (m *CommandSendError) GetMessage() string

func (*CommandSendError) GetProducerId

func (m *CommandSendError) GetProducerId() uint64

func (*CommandSendError) GetSequenceId

func (m *CommandSendError) GetSequenceId() uint64

func (*CommandSendError) Marshal

func (m *CommandSendError) Marshal() (dAtA []byte, err error)

func (*CommandSendError) MarshalTo

func (m *CommandSendError) MarshalTo(dAtA []byte) (int, error)

func (*CommandSendError) MarshalToSizedBuffer

func (m *CommandSendError) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSendError) ProtoMessage

func (*CommandSendError) ProtoMessage()

func (*CommandSendError) Reset

func (m *CommandSendError) Reset()

func (*CommandSendError) Size

func (m *CommandSendError) Size() (n int)

func (*CommandSendError) String

func (m *CommandSendError) String() string

func (*CommandSendError) Unmarshal

func (m *CommandSendError) Unmarshal(dAtA []byte) error

func (*CommandSendError) XXX_DiscardUnknown

func (m *CommandSendError) XXX_DiscardUnknown()

func (*CommandSendError) XXX_Marshal

func (m *CommandSendError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSendError) XXX_Merge

func (m *CommandSendError) XXX_Merge(src proto.Message)

func (*CommandSendError) XXX_Size

func (m *CommandSendError) XXX_Size() int

func (*CommandSendError) XXX_Unmarshal

func (m *CommandSendError) XXX_Unmarshal(b []byte) error

type CommandSendReceipt

type CommandSendReceipt struct {
	ProducerId           *uint64        `protobuf:"varint,1,req,name=producer_id,json=producerId" json:"producer_id,omitempty"`
	SequenceId           *uint64        `protobuf:"varint,2,req,name=sequence_id,json=sequenceId" json:"sequence_id,omitempty"`
	MessageId            *MessageIdData `protobuf:"bytes,3,opt,name=message_id,json=messageId" json:"message_id,omitempty"`
	HighestSequenceId    *uint64        `protobuf:"varint,4,opt,name=highest_sequence_id,json=highestSequenceId,def=0" json:"highest_sequence_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{}       `json:"-"`
	XXX_unrecognized     []byte         `json:"-"`
	XXX_sizecache        int32          `json:"-"`
}

func (*CommandSendReceipt) Descriptor

func (*CommandSendReceipt) Descriptor() ([]byte, []int)

func (*CommandSendReceipt) GetHighestSequenceId

func (m *CommandSendReceipt) GetHighestSequenceId() uint64

func (*CommandSendReceipt) GetMessageId

func (m *CommandSendReceipt) GetMessageId() *MessageIdData

func (*CommandSendReceipt) GetProducerId

func (m *CommandSendReceipt) GetProducerId() uint64

func (*CommandSendReceipt) GetSequenceId

func (m *CommandSendReceipt) GetSequenceId() uint64

func (*CommandSendReceipt) Marshal

func (m *CommandSendReceipt) Marshal() (dAtA []byte, err error)

func (*CommandSendReceipt) MarshalTo

func (m *CommandSendReceipt) MarshalTo(dAtA []byte) (int, error)

func (*CommandSendReceipt) MarshalToSizedBuffer

func (m *CommandSendReceipt) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSendReceipt) ProtoMessage

func (*CommandSendReceipt) ProtoMessage()

func (*CommandSendReceipt) Reset

func (m *CommandSendReceipt) Reset()

func (*CommandSendReceipt) Size

func (m *CommandSendReceipt) Size() (n int)

func (*CommandSendReceipt) String

func (m *CommandSendReceipt) String() string

func (*CommandSendReceipt) Unmarshal

func (m *CommandSendReceipt) Unmarshal(dAtA []byte) error

func (*CommandSendReceipt) XXX_DiscardUnknown

func (m *CommandSendReceipt) XXX_DiscardUnknown()

func (*CommandSendReceipt) XXX_Marshal

func (m *CommandSendReceipt) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSendReceipt) XXX_Merge

func (m *CommandSendReceipt) XXX_Merge(src proto.Message)

func (*CommandSendReceipt) XXX_Size

func (m *CommandSendReceipt) XXX_Size() int

func (*CommandSendReceipt) XXX_Unmarshal

func (m *CommandSendReceipt) XXX_Unmarshal(b []byte) error

type CommandSubscribe

type CommandSubscribe struct {
	Topic         *string                   `protobuf:"bytes,1,req,name=topic" json:"topic,omitempty"`
	Subscription  *string                   `protobuf:"bytes,2,req,name=subscription" json:"subscription,omitempty"`
	SubType       *CommandSubscribe_SubType `protobuf:"varint,3,req,name=subType,enum=pulsar.proto.CommandSubscribe_SubType" json:"subType,omitempty"`
	ConsumerId    *uint64                   `protobuf:"varint,4,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	RequestId     *uint64                   `protobuf:"varint,5,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	ConsumerName  *string                   `protobuf:"bytes,6,opt,name=consumer_name,json=consumerName" json:"consumer_name,omitempty"`
	PriorityLevel *int32                    `protobuf:"varint,7,opt,name=priority_level,json=priorityLevel" json:"priority_level,omitempty"`
	// Signal wether the subscription should be backed by a
	// durable cursor or not
	Durable *bool `protobuf:"varint,8,opt,name=durable,def=1" json:"durable,omitempty"`
	// If specified, the subscription will position the cursor
	// markd-delete position  on the particular message id and
	// will send messages from that point
	StartMessageId *MessageIdData `protobuf:"bytes,9,opt,name=start_message_id,json=startMessageId" json:"start_message_id,omitempty"`
	/// Add optional metadata key=value to this consumer
	Metadata      []*KeyValue `protobuf:"bytes,10,rep,name=metadata" json:"metadata,omitempty"`
	ReadCompacted *bool       `protobuf:"varint,11,opt,name=read_compacted,json=readCompacted" json:"read_compacted,omitempty"`
	Schema        *Schema     `protobuf:"bytes,12,opt,name=schema" json:"schema,omitempty"`
	// Signal whether the subscription will initialize on latest
	// or not -- earliest
	InitialPosition *CommandSubscribe_InitialPosition `` /* 135-byte string literal not displayed */
	// Mark the subscription as "replicated". Pulsar will make sure
	// to periodically sync the state of replicated subscriptions
	// across different clusters (when using geo-replication).
	ReplicateSubscriptionState *bool `` /* 136-byte string literal not displayed */
	// If true, the subscribe operation will cause a topic to be
	// created if it does not exist already (and if topic auto-creation
	// is allowed by broker.
	// If false, the subscribe operation will fail if the topic
	// does not exist.
	ForceTopicCreation *bool `protobuf:"varint,15,opt,name=force_topic_creation,json=forceTopicCreation,def=1" json:"force_topic_creation,omitempty"`
	// If specified, the subscription will reset cursor's position back
	// to specified seconds and  will send messages from that point
	StartMessageRollbackDurationSec *uint64        `` /* 161-byte string literal not displayed */
	KeySharedMeta                   *KeySharedMeta `protobuf:"bytes,17,opt,name=keySharedMeta" json:"keySharedMeta,omitempty"`
	XXX_NoUnkeyedLiteral            struct{}       `json:"-"`
	XXX_unrecognized                []byte         `json:"-"`
	XXX_sizecache                   int32          `json:"-"`
}

func (*CommandSubscribe) Descriptor

func (*CommandSubscribe) Descriptor() ([]byte, []int)

func (*CommandSubscribe) GetConsumerId

func (m *CommandSubscribe) GetConsumerId() uint64

func (*CommandSubscribe) GetConsumerName

func (m *CommandSubscribe) GetConsumerName() string

func (*CommandSubscribe) GetDurable

func (m *CommandSubscribe) GetDurable() bool

func (*CommandSubscribe) GetForceTopicCreation

func (m *CommandSubscribe) GetForceTopicCreation() bool

func (*CommandSubscribe) GetInitialPosition

func (m *CommandSubscribe) GetInitialPosition() CommandSubscribe_InitialPosition

func (*CommandSubscribe) GetKeySharedMeta

func (m *CommandSubscribe) GetKeySharedMeta() *KeySharedMeta

func (*CommandSubscribe) GetMetadata

func (m *CommandSubscribe) GetMetadata() []*KeyValue

func (*CommandSubscribe) GetPriorityLevel

func (m *CommandSubscribe) GetPriorityLevel() int32

func (*CommandSubscribe) GetReadCompacted

func (m *CommandSubscribe) GetReadCompacted() bool

func (*CommandSubscribe) GetReplicateSubscriptionState

func (m *CommandSubscribe) GetReplicateSubscriptionState() bool

func (*CommandSubscribe) GetRequestId

func (m *CommandSubscribe) GetRequestId() uint64

func (*CommandSubscribe) GetSchema

func (m *CommandSubscribe) GetSchema() *Schema

func (*CommandSubscribe) GetStartMessageId

func (m *CommandSubscribe) GetStartMessageId() *MessageIdData

func (*CommandSubscribe) GetStartMessageRollbackDurationSec

func (m *CommandSubscribe) GetStartMessageRollbackDurationSec() uint64

func (*CommandSubscribe) GetSubType

func (*CommandSubscribe) GetSubscription

func (m *CommandSubscribe) GetSubscription() string

func (*CommandSubscribe) GetTopic

func (m *CommandSubscribe) GetTopic() string

func (*CommandSubscribe) Marshal

func (m *CommandSubscribe) Marshal() (dAtA []byte, err error)

func (*CommandSubscribe) MarshalTo

func (m *CommandSubscribe) MarshalTo(dAtA []byte) (int, error)

func (*CommandSubscribe) MarshalToSizedBuffer

func (m *CommandSubscribe) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSubscribe) ProtoMessage

func (*CommandSubscribe) ProtoMessage()

func (*CommandSubscribe) Reset

func (m *CommandSubscribe) Reset()

func (*CommandSubscribe) Size

func (m *CommandSubscribe) Size() (n int)

func (*CommandSubscribe) String

func (m *CommandSubscribe) String() string

func (*CommandSubscribe) Unmarshal

func (m *CommandSubscribe) Unmarshal(dAtA []byte) error

func (*CommandSubscribe) XXX_DiscardUnknown

func (m *CommandSubscribe) XXX_DiscardUnknown()

func (*CommandSubscribe) XXX_Marshal

func (m *CommandSubscribe) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSubscribe) XXX_Merge

func (m *CommandSubscribe) XXX_Merge(src proto.Message)

func (*CommandSubscribe) XXX_Size

func (m *CommandSubscribe) XXX_Size() int

func (*CommandSubscribe) XXX_Unmarshal

func (m *CommandSubscribe) XXX_Unmarshal(b []byte) error

type CommandSubscribe_InitialPosition

type CommandSubscribe_InitialPosition int32
const (
	CommandSubscribe_Latest   CommandSubscribe_InitialPosition = 0
	CommandSubscribe_Earliest CommandSubscribe_InitialPosition = 1
)
const Default_CommandSubscribe_InitialPosition CommandSubscribe_InitialPosition = CommandSubscribe_Latest

func (CommandSubscribe_InitialPosition) Enum

func (CommandSubscribe_InitialPosition) EnumDescriptor

func (CommandSubscribe_InitialPosition) EnumDescriptor() ([]byte, []int)

func (CommandSubscribe_InitialPosition) String

func (*CommandSubscribe_InitialPosition) UnmarshalJSON

func (x *CommandSubscribe_InitialPosition) UnmarshalJSON(data []byte) error

type CommandSubscribe_SubType

type CommandSubscribe_SubType int32
const (
	CommandSubscribe_Exclusive  CommandSubscribe_SubType = 0
	CommandSubscribe_Shared     CommandSubscribe_SubType = 1
	CommandSubscribe_Failover   CommandSubscribe_SubType = 2
	CommandSubscribe_Key_Shared CommandSubscribe_SubType = 3
)

func (CommandSubscribe_SubType) Enum

func (CommandSubscribe_SubType) EnumDescriptor

func (CommandSubscribe_SubType) EnumDescriptor() ([]byte, []int)

func (CommandSubscribe_SubType) String

func (x CommandSubscribe_SubType) String() string

func (*CommandSubscribe_SubType) UnmarshalJSON

func (x *CommandSubscribe_SubType) UnmarshalJSON(data []byte) error

type CommandSuccess

type CommandSuccess struct {
	RequestId            *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Schema               *Schema  `protobuf:"bytes,2,opt,name=schema" json:"schema,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandSuccess) Descriptor

func (*CommandSuccess) Descriptor() ([]byte, []int)

func (*CommandSuccess) GetRequestId

func (m *CommandSuccess) GetRequestId() uint64

func (*CommandSuccess) GetSchema

func (m *CommandSuccess) GetSchema() *Schema

func (*CommandSuccess) Marshal

func (m *CommandSuccess) Marshal() (dAtA []byte, err error)

func (*CommandSuccess) MarshalTo

func (m *CommandSuccess) MarshalTo(dAtA []byte) (int, error)

func (*CommandSuccess) MarshalToSizedBuffer

func (m *CommandSuccess) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandSuccess) ProtoMessage

func (*CommandSuccess) ProtoMessage()

func (*CommandSuccess) Reset

func (m *CommandSuccess) Reset()

func (*CommandSuccess) Size

func (m *CommandSuccess) Size() (n int)

func (*CommandSuccess) String

func (m *CommandSuccess) String() string

func (*CommandSuccess) Unmarshal

func (m *CommandSuccess) Unmarshal(dAtA []byte) error

func (*CommandSuccess) XXX_DiscardUnknown

func (m *CommandSuccess) XXX_DiscardUnknown()

func (*CommandSuccess) XXX_Marshal

func (m *CommandSuccess) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandSuccess) XXX_Merge

func (m *CommandSuccess) XXX_Merge(src proto.Message)

func (*CommandSuccess) XXX_Size

func (m *CommandSuccess) XXX_Size() int

func (*CommandSuccess) XXX_Unmarshal

func (m *CommandSuccess) XXX_Unmarshal(b []byte) error

type CommandUnsubscribe

type CommandUnsubscribe struct {
	ConsumerId           *uint64  `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	RequestId            *uint64  `protobuf:"varint,2,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*CommandUnsubscribe) Descriptor

func (*CommandUnsubscribe) Descriptor() ([]byte, []int)

func (*CommandUnsubscribe) GetConsumerId

func (m *CommandUnsubscribe) GetConsumerId() uint64

func (*CommandUnsubscribe) GetRequestId

func (m *CommandUnsubscribe) GetRequestId() uint64

func (*CommandUnsubscribe) Marshal

func (m *CommandUnsubscribe) Marshal() (dAtA []byte, err error)

func (*CommandUnsubscribe) MarshalTo

func (m *CommandUnsubscribe) MarshalTo(dAtA []byte) (int, error)

func (*CommandUnsubscribe) MarshalToSizedBuffer

func (m *CommandUnsubscribe) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CommandUnsubscribe) ProtoMessage

func (*CommandUnsubscribe) ProtoMessage()

func (*CommandUnsubscribe) Reset

func (m *CommandUnsubscribe) Reset()

func (*CommandUnsubscribe) Size

func (m *CommandUnsubscribe) Size() (n int)

func (*CommandUnsubscribe) String

func (m *CommandUnsubscribe) String() string

func (*CommandUnsubscribe) Unmarshal

func (m *CommandUnsubscribe) Unmarshal(dAtA []byte) error

func (*CommandUnsubscribe) XXX_DiscardUnknown

func (m *CommandUnsubscribe) XXX_DiscardUnknown()

func (*CommandUnsubscribe) XXX_Marshal

func (m *CommandUnsubscribe) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CommandUnsubscribe) XXX_Merge

func (m *CommandUnsubscribe) XXX_Merge(src proto.Message)

func (*CommandUnsubscribe) XXX_Size

func (m *CommandUnsubscribe) XXX_Size() int

func (*CommandUnsubscribe) XXX_Unmarshal

func (m *CommandUnsubscribe) XXX_Unmarshal(b []byte) error

type CompressionType

type CompressionType int32
const (
	CompressionType_NONE   CompressionType = 0
	CompressionType_LZ4    CompressionType = 1
	CompressionType_ZLIB   CompressionType = 2
	CompressionType_ZSTD   CompressionType = 3
	CompressionType_SNAPPY CompressionType = 4
)
const Default_MessageMetadata_Compression CompressionType = CompressionType_NONE

func (CompressionType) Enum

func (x CompressionType) Enum() *CompressionType

func (CompressionType) EnumDescriptor

func (CompressionType) EnumDescriptor() ([]byte, []int)

func (CompressionType) String

func (x CompressionType) String() string

func (*CompressionType) UnmarshalJSON

func (x *CompressionType) UnmarshalJSON(data []byte) error

type EncryptionKeys

type EncryptionKeys struct {
	Key                  *string     `protobuf:"bytes,1,req,name=key" json:"key,omitempty"`
	Value                []byte      `protobuf:"bytes,2,req,name=value" json:"value,omitempty"`
	Metadata             []*KeyValue `protobuf:"bytes,3,rep,name=metadata" json:"metadata,omitempty"`
	XXX_NoUnkeyedLiteral struct{}    `json:"-"`
	XXX_unrecognized     []byte      `json:"-"`
	XXX_sizecache        int32       `json:"-"`
}

func (*EncryptionKeys) Descriptor

func (*EncryptionKeys) Descriptor() ([]byte, []int)

func (*EncryptionKeys) GetKey

func (m *EncryptionKeys) GetKey() string

func (*EncryptionKeys) GetMetadata

func (m *EncryptionKeys) GetMetadata() []*KeyValue

func (*EncryptionKeys) GetValue

func (m *EncryptionKeys) GetValue() []byte

func (*EncryptionKeys) Marshal

func (m *EncryptionKeys) Marshal() (dAtA []byte, err error)

func (*EncryptionKeys) MarshalTo

func (m *EncryptionKeys) MarshalTo(dAtA []byte) (int, error)

func (*EncryptionKeys) MarshalToSizedBuffer

func (m *EncryptionKeys) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*EncryptionKeys) ProtoMessage

func (*EncryptionKeys) ProtoMessage()

func (*EncryptionKeys) Reset

func (m *EncryptionKeys) Reset()

func (*EncryptionKeys) Size

func (m *EncryptionKeys) Size() (n int)

func (*EncryptionKeys) String

func (m *EncryptionKeys) String() string

func (*EncryptionKeys) Unmarshal

func (m *EncryptionKeys) Unmarshal(dAtA []byte) error

func (*EncryptionKeys) XXX_DiscardUnknown

func (m *EncryptionKeys) XXX_DiscardUnknown()

func (*EncryptionKeys) XXX_Marshal

func (m *EncryptionKeys) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*EncryptionKeys) XXX_Merge

func (m *EncryptionKeys) XXX_Merge(src proto.Message)

func (*EncryptionKeys) XXX_Size

func (m *EncryptionKeys) XXX_Size() int

func (*EncryptionKeys) XXX_Unmarshal

func (m *EncryptionKeys) XXX_Unmarshal(b []byte) error

type IntRange

type IntRange struct {
	Start                *int32   `protobuf:"varint,1,req,name=start" json:"start,omitempty"`
	End                  *int32   `protobuf:"varint,2,req,name=end" json:"end,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*IntRange) Descriptor

func (*IntRange) Descriptor() ([]byte, []int)

func (*IntRange) GetEnd

func (m *IntRange) GetEnd() int32

func (*IntRange) GetStart

func (m *IntRange) GetStart() int32

func (*IntRange) Marshal

func (m *IntRange) Marshal() (dAtA []byte, err error)

func (*IntRange) MarshalTo

func (m *IntRange) MarshalTo(dAtA []byte) (int, error)

func (*IntRange) MarshalToSizedBuffer

func (m *IntRange) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*IntRange) ProtoMessage

func (*IntRange) ProtoMessage()

func (*IntRange) Reset

func (m *IntRange) Reset()

func (*IntRange) Size

func (m *IntRange) Size() (n int)

func (*IntRange) String

func (m *IntRange) String() string

func (*IntRange) Unmarshal

func (m *IntRange) Unmarshal(dAtA []byte) error

func (*IntRange) XXX_DiscardUnknown

func (m *IntRange) XXX_DiscardUnknown()

func (*IntRange) XXX_Marshal

func (m *IntRange) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*IntRange) XXX_Merge

func (m *IntRange) XXX_Merge(src proto.Message)

func (*IntRange) XXX_Size

func (m *IntRange) XXX_Size() int

func (*IntRange) XXX_Unmarshal

func (m *IntRange) XXX_Unmarshal(b []byte) error

type KeyLongValue

type KeyLongValue struct {
	Key                  *string  `protobuf:"bytes,1,req,name=key" json:"key,omitempty"`
	Value                *uint64  `protobuf:"varint,2,req,name=value" json:"value,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*KeyLongValue) Descriptor

func (*KeyLongValue) Descriptor() ([]byte, []int)

func (*KeyLongValue) GetKey

func (m *KeyLongValue) GetKey() string

func (*KeyLongValue) GetValue

func (m *KeyLongValue) GetValue() uint64

func (*KeyLongValue) Marshal

func (m *KeyLongValue) Marshal() (dAtA []byte, err error)

func (*KeyLongValue) MarshalTo

func (m *KeyLongValue) MarshalTo(dAtA []byte) (int, error)

func (*KeyLongValue) MarshalToSizedBuffer

func (m *KeyLongValue) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*KeyLongValue) ProtoMessage

func (*KeyLongValue) ProtoMessage()

func (*KeyLongValue) Reset

func (m *KeyLongValue) Reset()

func (*KeyLongValue) Size

func (m *KeyLongValue) Size() (n int)

func (*KeyLongValue) String

func (m *KeyLongValue) String() string

func (*KeyLongValue) Unmarshal

func (m *KeyLongValue) Unmarshal(dAtA []byte) error

func (*KeyLongValue) XXX_DiscardUnknown

func (m *KeyLongValue) XXX_DiscardUnknown()

func (*KeyLongValue) XXX_Marshal

func (m *KeyLongValue) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*KeyLongValue) XXX_Merge

func (m *KeyLongValue) XXX_Merge(src proto.Message)

func (*KeyLongValue) XXX_Size

func (m *KeyLongValue) XXX_Size() int

func (*KeyLongValue) XXX_Unmarshal

func (m *KeyLongValue) XXX_Unmarshal(b []byte) error

type KeySharedMeta

type KeySharedMeta struct {
	KeySharedMode        *KeySharedMode `protobuf:"varint,1,req,name=keySharedMode,enum=pulsar.proto.KeySharedMode" json:"keySharedMode,omitempty"`
	HashRanges           []*IntRange    `protobuf:"bytes,3,rep,name=hashRanges" json:"hashRanges,omitempty"`
	XXX_NoUnkeyedLiteral struct{}       `json:"-"`
	XXX_unrecognized     []byte         `json:"-"`
	XXX_sizecache        int32          `json:"-"`
}

func (*KeySharedMeta) Descriptor

func (*KeySharedMeta) Descriptor() ([]byte, []int)

func (*KeySharedMeta) GetHashRanges

func (m *KeySharedMeta) GetHashRanges() []*IntRange

func (*KeySharedMeta) GetKeySharedMode

func (m *KeySharedMeta) GetKeySharedMode() KeySharedMode

func (*KeySharedMeta) Marshal

func (m *KeySharedMeta) Marshal() (dAtA []byte, err error)

func (*KeySharedMeta) MarshalTo

func (m *KeySharedMeta) MarshalTo(dAtA []byte) (int, error)

func (*KeySharedMeta) MarshalToSizedBuffer

func (m *KeySharedMeta) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*KeySharedMeta) ProtoMessage

func (*KeySharedMeta) ProtoMessage()

func (*KeySharedMeta) Reset

func (m *KeySharedMeta) Reset()

func (*KeySharedMeta) Size

func (m *KeySharedMeta) Size() (n int)

func (*KeySharedMeta) String

func (m *KeySharedMeta) String() string

func (*KeySharedMeta) Unmarshal

func (m *KeySharedMeta) Unmarshal(dAtA []byte) error

func (*KeySharedMeta) XXX_DiscardUnknown

func (m *KeySharedMeta) XXX_DiscardUnknown()

func (*KeySharedMeta) XXX_Marshal

func (m *KeySharedMeta) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*KeySharedMeta) XXX_Merge

func (m *KeySharedMeta) XXX_Merge(src proto.Message)

func (*KeySharedMeta) XXX_Size

func (m *KeySharedMeta) XXX_Size() int

func (*KeySharedMeta) XXX_Unmarshal

func (m *KeySharedMeta) XXX_Unmarshal(b []byte) error

type KeySharedMode

type KeySharedMode int32
const (
	KeySharedMode_AUTO_SPLIT KeySharedMode = 0
	KeySharedMode_STICKY     KeySharedMode = 1
)

func (KeySharedMode) Enum

func (x KeySharedMode) Enum() *KeySharedMode

func (KeySharedMode) EnumDescriptor

func (KeySharedMode) EnumDescriptor() ([]byte, []int)

func (KeySharedMode) String

func (x KeySharedMode) String() string

func (*KeySharedMode) UnmarshalJSON

func (x *KeySharedMode) UnmarshalJSON(data []byte) error

type KeyValue

type KeyValue struct {
	Key                  *string  `protobuf:"bytes,1,req,name=key" json:"key,omitempty"`
	Value                *string  `protobuf:"bytes,2,req,name=value" json:"value,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*KeyValue) Descriptor

func (*KeyValue) Descriptor() ([]byte, []int)

func (*KeyValue) GetKey

func (m *KeyValue) GetKey() string

func (*KeyValue) GetValue

func (m *KeyValue) GetValue() string

func (*KeyValue) Marshal

func (m *KeyValue) Marshal() (dAtA []byte, err error)

func (*KeyValue) MarshalTo

func (m *KeyValue) MarshalTo(dAtA []byte) (int, error)

func (*KeyValue) MarshalToSizedBuffer

func (m *KeyValue) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*KeyValue) ProtoMessage

func (*KeyValue) ProtoMessage()

func (*KeyValue) Reset

func (m *KeyValue) Reset()

func (*KeyValue) Size

func (m *KeyValue) Size() (n int)

func (*KeyValue) String

func (m *KeyValue) String() string

func (*KeyValue) Unmarshal

func (m *KeyValue) Unmarshal(dAtA []byte) error

func (*KeyValue) XXX_DiscardUnknown

func (m *KeyValue) XXX_DiscardUnknown()

func (*KeyValue) XXX_Marshal

func (m *KeyValue) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*KeyValue) XXX_Merge

func (m *KeyValue) XXX_Merge(src proto.Message)

func (*KeyValue) XXX_Size

func (m *KeyValue) XXX_Size() int

func (*KeyValue) XXX_Unmarshal

func (m *KeyValue) XXX_Unmarshal(b []byte) error

type MessageIdData

type MessageIdData struct {
	LedgerId             *uint64  `protobuf:"varint,1,req,name=ledgerId" json:"ledgerId,omitempty"`
	EntryId              *uint64  `protobuf:"varint,2,req,name=entryId" json:"entryId,omitempty"`
	Partition            *int32   `protobuf:"varint,3,opt,name=partition,def=-1" json:"partition,omitempty"`
	BatchIndex           *int32   `protobuf:"varint,4,opt,name=batch_index,json=batchIndex,def=-1" json:"batch_index,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*MessageIdData) Descriptor

func (*MessageIdData) Descriptor() ([]byte, []int)

func (*MessageIdData) GetBatchIndex

func (m *MessageIdData) GetBatchIndex() int32

func (*MessageIdData) GetEntryId

func (m *MessageIdData) GetEntryId() uint64

func (*MessageIdData) GetLedgerId

func (m *MessageIdData) GetLedgerId() uint64

func (*MessageIdData) GetPartition

func (m *MessageIdData) GetPartition() int32

func (*MessageIdData) Marshal

func (m *MessageIdData) Marshal() (dAtA []byte, err error)

func (*MessageIdData) MarshalTo

func (m *MessageIdData) MarshalTo(dAtA []byte) (int, error)

func (*MessageIdData) MarshalToSizedBuffer

func (m *MessageIdData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MessageIdData) ProtoMessage

func (*MessageIdData) ProtoMessage()

func (*MessageIdData) Reset

func (m *MessageIdData) Reset()

func (*MessageIdData) Size

func (m *MessageIdData) Size() (n int)

func (*MessageIdData) String

func (m *MessageIdData) String() string

func (*MessageIdData) Unmarshal

func (m *MessageIdData) Unmarshal(dAtA []byte) error

func (*MessageIdData) XXX_DiscardUnknown

func (m *MessageIdData) XXX_DiscardUnknown()

func (*MessageIdData) XXX_Marshal

func (m *MessageIdData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MessageIdData) XXX_Merge

func (m *MessageIdData) XXX_Merge(src proto.Message)

func (*MessageIdData) XXX_Size

func (m *MessageIdData) XXX_Size() int

func (*MessageIdData) XXX_Unmarshal

func (m *MessageIdData) XXX_Unmarshal(b []byte) error

type MessageMetadata

type MessageMetadata struct {
	ProducerName *string     `protobuf:"bytes,1,req,name=producer_name,json=producerName" json:"producer_name,omitempty"`
	SequenceId   *uint64     `protobuf:"varint,2,req,name=sequence_id,json=sequenceId" json:"sequence_id,omitempty"`
	PublishTime  *uint64     `protobuf:"varint,3,req,name=publish_time,json=publishTime" json:"publish_time,omitempty"`
	Properties   []*KeyValue `protobuf:"bytes,4,rep,name=properties" json:"properties,omitempty"`
	// Property set on replicated message,
	// includes the source cluster name
	ReplicatedFrom *string `protobuf:"bytes,5,opt,name=replicated_from,json=replicatedFrom" json:"replicated_from,omitempty"`
	//key to decide partition for the msg
	PartitionKey *string `protobuf:"bytes,6,opt,name=partition_key,json=partitionKey" json:"partition_key,omitempty"`
	// Override namespace's replication
	ReplicateTo      []string         `protobuf:"bytes,7,rep,name=replicate_to,json=replicateTo" json:"replicate_to,omitempty"`
	Compression      *CompressionType `protobuf:"varint,8,opt,name=compression,enum=pulsar.proto.CompressionType,def=0" json:"compression,omitempty"`
	UncompressedSize *uint32          `protobuf:"varint,9,opt,name=uncompressed_size,json=uncompressedSize,def=0" json:"uncompressed_size,omitempty"`
	// Removed below checksum field from Metadata as
	// it should be part of send-command which keeps checksum of header + payload
	//optional sfixed64 checksum = 10;
	// differentiate single and batch message metadata
	NumMessagesInBatch *int32 `protobuf:"varint,11,opt,name=num_messages_in_batch,json=numMessagesInBatch,def=1" json:"num_messages_in_batch,omitempty"`
	// the timestamp that this event occurs. it is typically set by applications.
	// if this field is omitted, `publish_time` can be used for the purpose of `event_time`.
	EventTime *uint64 `protobuf:"varint,12,opt,name=event_time,json=eventTime,def=0" json:"event_time,omitempty"`
	// Contains encryption key name, encrypted key and metadata to describe the key
	EncryptionKeys []*EncryptionKeys `protobuf:"bytes,13,rep,name=encryption_keys,json=encryptionKeys" json:"encryption_keys,omitempty"`
	// Algorithm used to encrypt data key
	EncryptionAlgo *string `protobuf:"bytes,14,opt,name=encryption_algo,json=encryptionAlgo" json:"encryption_algo,omitempty"`
	// Additional parameters required by encryption
	EncryptionParam        []byte `protobuf:"bytes,15,opt,name=encryption_param,json=encryptionParam" json:"encryption_param,omitempty"`
	SchemaVersion          []byte `protobuf:"bytes,16,opt,name=schema_version,json=schemaVersion" json:"schema_version,omitempty"`
	PartitionKeyB64Encoded *bool  `` /* 132-byte string literal not displayed */
	// Specific a key to overwrite the message key which used for ordering dispatch in Key_Shared mode.
	OrderingKey []byte `protobuf:"bytes,18,opt,name=ordering_key,json=orderingKey" json:"ordering_key,omitempty"`
	// Mark the message to be delivered at or after the specified timestamp
	DeliverAtTime *int64 `protobuf:"varint,19,opt,name=deliver_at_time,json=deliverAtTime" json:"deliver_at_time,omitempty"`
	// Identify whether a message is a "marker" message used for
	// internal metadata instead of application published data.
	// Markers will generally not be propagated back to clients
	MarkerType *int32 `protobuf:"varint,20,opt,name=marker_type,json=markerType" json:"marker_type,omitempty"`
	// transaction related message info
	TxnidLeastBits *uint64 `protobuf:"varint,22,opt,name=txnid_least_bits,json=txnidLeastBits,def=0" json:"txnid_least_bits,omitempty"`
	TxnidMostBits  *uint64 `protobuf:"varint,23,opt,name=txnid_most_bits,json=txnidMostBits,def=0" json:"txnid_most_bits,omitempty"`
	/// Add highest sequence id to support batch message with external sequence id
	HighestSequenceId    *uint64  `protobuf:"varint,24,opt,name=highest_sequence_id,json=highestSequenceId,def=0" json:"highest_sequence_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*MessageMetadata) Descriptor

func (*MessageMetadata) Descriptor() ([]byte, []int)

func (*MessageMetadata) GetCompression

func (m *MessageMetadata) GetCompression() CompressionType

func (*MessageMetadata) GetDeliverAtTime

func (m *MessageMetadata) GetDeliverAtTime() int64

func (*MessageMetadata) GetEncryptionAlgo

func (m *MessageMetadata) GetEncryptionAlgo() string

func (*MessageMetadata) GetEncryptionKeys

func (m *MessageMetadata) GetEncryptionKeys() []*EncryptionKeys

func (*MessageMetadata) GetEncryptionParam

func (m *MessageMetadata) GetEncryptionParam() []byte

func (*MessageMetadata) GetEventTime

func (m *MessageMetadata) GetEventTime() uint64

func (*MessageMetadata) GetHighestSequenceId

func (m *MessageMetadata) GetHighestSequenceId() uint64

func (*MessageMetadata) GetMarkerType

func (m *MessageMetadata) GetMarkerType() int32

func (*MessageMetadata) GetNumMessagesInBatch

func (m *MessageMetadata) GetNumMessagesInBatch() int32

func (*MessageMetadata) GetOrderingKey

func (m *MessageMetadata) GetOrderingKey() []byte

func (*MessageMetadata) GetPartitionKey

func (m *MessageMetadata) GetPartitionKey() string

func (*MessageMetadata) GetPartitionKeyB64Encoded

func (m *MessageMetadata) GetPartitionKeyB64Encoded() bool

func (*MessageMetadata) GetProducerName

func (m *MessageMetadata) GetProducerName() string

func (*MessageMetadata) GetProperties

func (m *MessageMetadata) GetProperties() []*KeyValue

func (*MessageMetadata) GetPublishTime

func (m *MessageMetadata) GetPublishTime() uint64

func (*MessageMetadata) GetReplicateTo

func (m *MessageMetadata) GetReplicateTo() []string

func (*MessageMetadata) GetReplicatedFrom

func (m *MessageMetadata) GetReplicatedFrom() string

func (*MessageMetadata) GetSchemaVersion

func (m *MessageMetadata) GetSchemaVersion() []byte

func (*MessageMetadata) GetSequenceId

func (m *MessageMetadata) GetSequenceId() uint64

func (*MessageMetadata) GetTxnidLeastBits

func (m *MessageMetadata) GetTxnidLeastBits() uint64

func (*MessageMetadata) GetTxnidMostBits

func (m *MessageMetadata) GetTxnidMostBits() uint64

func (*MessageMetadata) GetUncompressedSize

func (m *MessageMetadata) GetUncompressedSize() uint32

func (*MessageMetadata) Marshal

func (m *MessageMetadata) Marshal() (dAtA []byte, err error)

func (*MessageMetadata) MarshalTo

func (m *MessageMetadata) MarshalTo(dAtA []byte) (int, error)

func (*MessageMetadata) MarshalToSizedBuffer

func (m *MessageMetadata) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MessageMetadata) ProtoMessage

func (*MessageMetadata) ProtoMessage()

func (*MessageMetadata) Reset

func (m *MessageMetadata) Reset()

func (*MessageMetadata) Size

func (m *MessageMetadata) Size() (n int)

func (*MessageMetadata) String

func (m *MessageMetadata) String() string

func (*MessageMetadata) Unmarshal

func (m *MessageMetadata) Unmarshal(dAtA []byte) error

func (*MessageMetadata) XXX_DiscardUnknown

func (m *MessageMetadata) XXX_DiscardUnknown()

func (*MessageMetadata) XXX_Marshal

func (m *MessageMetadata) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MessageMetadata) XXX_Merge

func (m *MessageMetadata) XXX_Merge(src proto.Message)

func (*MessageMetadata) XXX_Size

func (m *MessageMetadata) XXX_Size() int

func (*MessageMetadata) XXX_Unmarshal

func (m *MessageMetadata) XXX_Unmarshal(b []byte) error

type ProtocolVersion

type ProtocolVersion int32

Each protocol version identify new features that are incrementally added to the protocol

const (
	ProtocolVersion_v0  ProtocolVersion = 0
	ProtocolVersion_v1  ProtocolVersion = 1
	ProtocolVersion_v2  ProtocolVersion = 2
	ProtocolVersion_v3  ProtocolVersion = 3
	ProtocolVersion_v4  ProtocolVersion = 4
	ProtocolVersion_v5  ProtocolVersion = 5
	ProtocolVersion_v6  ProtocolVersion = 6
	ProtocolVersion_v7  ProtocolVersion = 7
	ProtocolVersion_v8  ProtocolVersion = 8
	ProtocolVersion_v9  ProtocolVersion = 9
	ProtocolVersion_v10 ProtocolVersion = 10
	ProtocolVersion_v11 ProtocolVersion = 11
	ProtocolVersion_v12 ProtocolVersion = 12
	// Added CommandActiveConsumerChange
	// Added CommandGetTopicsOfNamespace
	ProtocolVersion_v13 ProtocolVersion = 13
	ProtocolVersion_v14 ProtocolVersion = 14
	// Added Key_Shared subscription
	ProtocolVersion_v15 ProtocolVersion = 15
)

func (ProtocolVersion) Enum

func (x ProtocolVersion) Enum() *ProtocolVersion

func (ProtocolVersion) EnumDescriptor

func (ProtocolVersion) EnumDescriptor() ([]byte, []int)

func (ProtocolVersion) String

func (x ProtocolVersion) String() string

func (*ProtocolVersion) UnmarshalJSON

func (x *ProtocolVersion) UnmarshalJSON(data []byte) error

type Schema

type Schema struct {
	Name                 *string      `protobuf:"bytes,1,req,name=name" json:"name,omitempty"`
	SchemaData           []byte       `protobuf:"bytes,3,req,name=schema_data,json=schemaData" json:"schema_data,omitempty"`
	Type                 *Schema_Type `protobuf:"varint,4,req,name=type,enum=pulsar.proto.Schema_Type" json:"type,omitempty"`
	Properties           []*KeyValue  `protobuf:"bytes,5,rep,name=properties" json:"properties,omitempty"`
	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
	XXX_unrecognized     []byte       `json:"-"`
	XXX_sizecache        int32        `json:"-"`
}

func (*Schema) Descriptor

func (*Schema) Descriptor() ([]byte, []int)

func (*Schema) GetName

func (m *Schema) GetName() string

func (*Schema) GetProperties

func (m *Schema) GetProperties() []*KeyValue

func (*Schema) GetSchemaData

func (m *Schema) GetSchemaData() []byte

func (*Schema) GetType

func (m *Schema) GetType() Schema_Type

func (*Schema) Marshal

func (m *Schema) Marshal() (dAtA []byte, err error)

func (*Schema) MarshalTo

func (m *Schema) MarshalTo(dAtA []byte) (int, error)

func (*Schema) MarshalToSizedBuffer

func (m *Schema) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Schema) ProtoMessage

func (*Schema) ProtoMessage()

func (*Schema) Reset

func (m *Schema) Reset()

func (*Schema) Size

func (m *Schema) Size() (n int)

func (*Schema) String

func (m *Schema) String() string

func (*Schema) Unmarshal

func (m *Schema) Unmarshal(dAtA []byte) error

func (*Schema) XXX_DiscardUnknown

func (m *Schema) XXX_DiscardUnknown()

func (*Schema) XXX_Marshal

func (m *Schema) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Schema) XXX_Merge

func (m *Schema) XXX_Merge(src proto.Message)

func (*Schema) XXX_Size

func (m *Schema) XXX_Size() int

func (*Schema) XXX_Unmarshal

func (m *Schema) XXX_Unmarshal(b []byte) error

type Schema_Type

type Schema_Type int32
const (
	Schema_None      Schema_Type = 0
	Schema_String    Schema_Type = 1
	Schema_Json      Schema_Type = 2
	Schema_Protobuf  Schema_Type = 3
	Schema_Avro      Schema_Type = 4
	Schema_Bool      Schema_Type = 5
	Schema_Int8      Schema_Type = 6
	Schema_Int16     Schema_Type = 7
	Schema_Int32     Schema_Type = 8
	Schema_Int64     Schema_Type = 9
	Schema_Float     Schema_Type = 10
	Schema_Double    Schema_Type = 11
	Schema_Date      Schema_Type = 12
	Schema_Time      Schema_Type = 13
	Schema_Timestamp Schema_Type = 14
	Schema_KeyValue  Schema_Type = 15
)

func (Schema_Type) Enum

func (x Schema_Type) Enum() *Schema_Type

func (Schema_Type) EnumDescriptor

func (Schema_Type) EnumDescriptor() ([]byte, []int)

func (Schema_Type) String

func (x Schema_Type) String() string

func (*Schema_Type) UnmarshalJSON

func (x *Schema_Type) UnmarshalJSON(data []byte) error

type ServerError

type ServerError int32
const (
	ServerError_UnknownError        ServerError = 0
	ServerError_MetadataError       ServerError = 1
	ServerError_PersistenceError    ServerError = 2
	ServerError_AuthenticationError ServerError = 3
	ServerError_AuthorizationError  ServerError = 4
	ServerError_ConsumerBusy        ServerError = 5
	// other consumers are connected
	ServerError_ServiceNotReady                       ServerError = 6
	ServerError_ProducerBlockedQuotaExceededError     ServerError = 7
	ServerError_ProducerBlockedQuotaExceededException ServerError = 8
	ServerError_ChecksumError                         ServerError = 9
	ServerError_UnsupportedVersionError               ServerError = 10
	ServerError_TopicNotFound                         ServerError = 11
	ServerError_SubscriptionNotFound                  ServerError = 12
	ServerError_ConsumerNotFound                      ServerError = 13
	ServerError_TooManyRequests                       ServerError = 14
	ServerError_TopicTerminatedError                  ServerError = 15
	ServerError_ProducerBusy                          ServerError = 16
	ServerError_InvalidTopicName                      ServerError = 17
	ServerError_IncompatibleSchema                    ServerError = 18
	ServerError_ConsumerAssignError                   ServerError = 19
	ServerError_TransactionCoordinatorNotFound        ServerError = 20
	ServerError_InvalidTxnStatus                      ServerError = 21
)

func (ServerError) Enum

func (x ServerError) Enum() *ServerError

func (ServerError) EnumDescriptor

func (ServerError) EnumDescriptor() ([]byte, []int)

func (ServerError) String

func (x ServerError) String() string

func (*ServerError) UnmarshalJSON

func (x *ServerError) UnmarshalJSON(data []byte) error

type SingleMessageMetadata

type SingleMessageMetadata struct {
	Properties   []*KeyValue `protobuf:"bytes,1,rep,name=properties" json:"properties,omitempty"`
	PartitionKey *string     `protobuf:"bytes,2,opt,name=partition_key,json=partitionKey" json:"partition_key,omitempty"`
	PayloadSize  *int32      `protobuf:"varint,3,req,name=payload_size,json=payloadSize" json:"payload_size,omitempty"`
	CompactedOut *bool       `protobuf:"varint,4,opt,name=compacted_out,json=compactedOut,def=0" json:"compacted_out,omitempty"`
	// the timestamp that this event occurs. it is typically set by applications.
	// if this field is omitted, `publish_time` can be used for the purpose of `event_time`.
	EventTime              *uint64 `protobuf:"varint,5,opt,name=event_time,json=eventTime,def=0" json:"event_time,omitempty"`
	PartitionKeyB64Encoded *bool   `` /* 131-byte string literal not displayed */
	// Specific a key to overwrite the message key which used for ordering dispatch in Key_Shared mode.
	OrderingKey []byte `protobuf:"bytes,7,opt,name=ordering_key,json=orderingKey" json:"ordering_key,omitempty"`
	// Allows consumer retrieve the sequence id that the producer set.
	SequenceId           *uint64  `protobuf:"varint,8,opt,name=sequence_id,json=sequenceId" json:"sequence_id,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*SingleMessageMetadata) Descriptor

func (*SingleMessageMetadata) Descriptor() ([]byte, []int)

func (*SingleMessageMetadata) GetCompactedOut

func (m *SingleMessageMetadata) GetCompactedOut() bool

func (*SingleMessageMetadata) GetEventTime

func (m *SingleMessageMetadata) GetEventTime() uint64

func (*SingleMessageMetadata) GetOrderingKey

func (m *SingleMessageMetadata) GetOrderingKey() []byte

func (*SingleMessageMetadata) GetPartitionKey

func (m *SingleMessageMetadata) GetPartitionKey() string

func (*SingleMessageMetadata) GetPartitionKeyB64Encoded

func (m *SingleMessageMetadata) GetPartitionKeyB64Encoded() bool

func (*SingleMessageMetadata) GetPayloadSize

func (m *SingleMessageMetadata) GetPayloadSize() int32

func (*SingleMessageMetadata) GetProperties

func (m *SingleMessageMetadata) GetProperties() []*KeyValue

func (*SingleMessageMetadata) GetSequenceId

func (m *SingleMessageMetadata) GetSequenceId() uint64

func (*SingleMessageMetadata) Marshal

func (m *SingleMessageMetadata) Marshal() (dAtA []byte, err error)

func (*SingleMessageMetadata) MarshalTo

func (m *SingleMessageMetadata) MarshalTo(dAtA []byte) (int, error)

func (*SingleMessageMetadata) MarshalToSizedBuffer

func (m *SingleMessageMetadata) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SingleMessageMetadata) ProtoMessage

func (*SingleMessageMetadata) ProtoMessage()

func (*SingleMessageMetadata) Reset

func (m *SingleMessageMetadata) Reset()

func (*SingleMessageMetadata) Size

func (m *SingleMessageMetadata) Size() (n int)

func (*SingleMessageMetadata) String

func (m *SingleMessageMetadata) String() string

func (*SingleMessageMetadata) Unmarshal

func (m *SingleMessageMetadata) Unmarshal(dAtA []byte) error

func (*SingleMessageMetadata) XXX_DiscardUnknown

func (m *SingleMessageMetadata) XXX_DiscardUnknown()

func (*SingleMessageMetadata) XXX_Marshal

func (m *SingleMessageMetadata) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SingleMessageMetadata) XXX_Merge

func (m *SingleMessageMetadata) XXX_Merge(src proto.Message)

func (*SingleMessageMetadata) XXX_Size

func (m *SingleMessageMetadata) XXX_Size() int

func (*SingleMessageMetadata) XXX_Unmarshal

func (m *SingleMessageMetadata) XXX_Unmarshal(b []byte) error

type Subscription

type Subscription struct {
	Topic                *string  `protobuf:"bytes,1,req,name=topic" json:"topic,omitempty"`
	Subscription         *string  `protobuf:"bytes,2,req,name=subscription" json:"subscription,omitempty"`
	XXX_NoUnkeyedLiteral struct{} `json:"-"`
	XXX_unrecognized     []byte   `json:"-"`
	XXX_sizecache        int32    `json:"-"`
}

func (*Subscription) Descriptor

func (*Subscription) Descriptor() ([]byte, []int)

func (*Subscription) GetSubscription

func (m *Subscription) GetSubscription() string

func (*Subscription) GetTopic

func (m *Subscription) GetTopic() string

func (*Subscription) Marshal

func (m *Subscription) Marshal() (dAtA []byte, err error)

func (*Subscription) MarshalTo

func (m *Subscription) MarshalTo(dAtA []byte) (int, error)

func (*Subscription) MarshalToSizedBuffer

func (m *Subscription) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Subscription) ProtoMessage

func (*Subscription) ProtoMessage()

func (*Subscription) Reset

func (m *Subscription) Reset()

func (*Subscription) Size

func (m *Subscription) Size() (n int)

func (*Subscription) String

func (m *Subscription) String() string

func (*Subscription) Unmarshal

func (m *Subscription) Unmarshal(dAtA []byte) error

func (*Subscription) XXX_DiscardUnknown

func (m *Subscription) XXX_DiscardUnknown()

func (*Subscription) XXX_Marshal

func (m *Subscription) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Subscription) XXX_Merge

func (m *Subscription) XXX_Merge(src proto.Message)

func (*Subscription) XXX_Size

func (m *Subscription) XXX_Size() int

func (*Subscription) XXX_Unmarshal

func (m *Subscription) XXX_Unmarshal(b []byte) error

type TxnAction

type TxnAction int32
const (
	TxnAction_COMMIT TxnAction = 0
	TxnAction_ABORT  TxnAction = 1
)

func (TxnAction) Enum

func (x TxnAction) Enum() *TxnAction

func (TxnAction) EnumDescriptor

func (TxnAction) EnumDescriptor() ([]byte, []int)

func (TxnAction) String

func (x TxnAction) String() string

func (*TxnAction) UnmarshalJSON

func (x *TxnAction) UnmarshalJSON(data []byte) error

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL