proto

package
v0.12.1 Latest Latest
Warning

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

Go to latest
Published: Feb 29, 2024 License: Apache-2.0 Imports: 4 Imported by: 0

README

protoc-gen-go:

go install google.golang.org/protobuf/cmd/protoc-gen-go@latest

Generate code:

protoc --go_out=. --go_opt=paths=source_relative PulsarApi.proto

Documentation

Index

Constants

View Source
const (
	Default_MessageIdData_Partition  = int32(-1)
	Default_MessageIdData_BatchIndex = int32(-1)
)

Default values for MessageIdData fields.

View Source
const (
	Default_MessageMetadata_Compression            = CompressionType_NONE
	Default_MessageMetadata_UncompressedSize       = uint32(0)
	Default_MessageMetadata_NumMessagesInBatch     = int32(1)
	Default_MessageMetadata_EventTime              = uint64(0)
	Default_MessageMetadata_PartitionKeyB64Encoded = bool(false)
	Default_MessageMetadata_HighestSequenceId      = uint64(0)
	Default_MessageMetadata_NullValue              = bool(false)
	Default_MessageMetadata_NullPartitionKey       = bool(false)
)

Default values for MessageMetadata fields.

View Source
const (
	Default_SingleMessageMetadata_CompactedOut           = bool(false)
	Default_SingleMessageMetadata_EventTime              = uint64(0)
	Default_SingleMessageMetadata_PartitionKeyB64Encoded = bool(false)
	Default_SingleMessageMetadata_NullValue              = bool(false)
	Default_SingleMessageMetadata_NullPartitionKey       = bool(false)
)

Default values for SingleMessageMetadata fields.

View Source
const (
	Default_FeatureFlags_SupportsAuthRefresh         = bool(false)
	Default_FeatureFlags_SupportsBrokerEntryMetadata = bool(false)
	Default_FeatureFlags_SupportsPartialProducer     = bool(false)
	Default_FeatureFlags_SupportsTopicWatchers       = bool(false)
)

Default values for FeatureFlags fields.

View Source
const (
	Default_CommandSubscribe_Durable                         = bool(true)
	Default_CommandSubscribe_InitialPosition                 = CommandSubscribe_Latest
	Default_CommandSubscribe_ForceTopicCreation              = bool(true)
	Default_CommandSubscribe_StartMessageRollbackDurationSec = uint64(0)
)

Default values for CommandSubscribe fields.

View Source
const (
	Default_CommandLookupTopicResponse_Authoritative          = bool(false)
	Default_CommandLookupTopicResponse_ProxyThroughServiceUrl = bool(false)
)

Default values for CommandLookupTopicResponse fields.

View Source
const (
	Default_CommandProducer_Encrypted                = bool(false)
	Default_CommandProducer_Epoch                    = uint64(0)
	Default_CommandProducer_UserProvidedProducerName = bool(true)
	Default_CommandProducer_ProducerAccessMode       = ProducerAccessMode_Shared
	Default_CommandProducer_TxnEnabled               = bool(false)
)

Default values for CommandProducer fields.

View Source
const (
	Default_CommandSend_NumMessages       = int32(1)
	Default_CommandSend_TxnidLeastBits    = uint64(0)
	Default_CommandSend_TxnidMostBits     = uint64(0)
	Default_CommandSend_HighestSequenceId = uint64(0)
	Default_CommandSend_IsChunk           = bool(false)
	Default_CommandSend_Marker            = bool(false)
)

Default values for CommandSend fields.

View Source
const (
	Default_CommandAck_TxnidLeastBits = uint64(0)
	Default_CommandAck_TxnidMostBits  = uint64(0)
)

Default values for CommandAck fields.

View Source
const (
	Default_CommandAckResponse_TxnidLeastBits = uint64(0)
	Default_CommandAckResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandAckResponse fields.

View Source
const (
	Default_CommandProducerSuccess_LastSequenceId = int64(-1)
	Default_CommandProducerSuccess_ProducerReady  = bool(true)
)

Default values for CommandProducerSuccess fields.

View Source
const (
	Default_CommandGetTopicsOfNamespaceResponse_Filtered = bool(false)
	Default_CommandGetTopicsOfNamespaceResponse_Changed  = bool(true)
)

Default values for CommandGetTopicsOfNamespaceResponse fields.

View Source
const (
	Default_CommandNewTxn_TxnTtlSeconds = uint64(0)
	Default_CommandNewTxn_TcId          = uint64(0)
)

Default values for CommandNewTxn fields.

View Source
const (
	Default_CommandNewTxnResponse_TxnidLeastBits = uint64(0)
	Default_CommandNewTxnResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandNewTxnResponse fields.

View Source
const (
	Default_CommandAddPartitionToTxn_TxnidLeastBits = uint64(0)
	Default_CommandAddPartitionToTxn_TxnidMostBits  = uint64(0)
)

Default values for CommandAddPartitionToTxn fields.

View Source
const (
	Default_CommandAddPartitionToTxnResponse_TxnidLeastBits = uint64(0)
	Default_CommandAddPartitionToTxnResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandAddPartitionToTxnResponse fields.

View Source
const (
	Default_CommandAddSubscriptionToTxn_TxnidLeastBits = uint64(0)
	Default_CommandAddSubscriptionToTxn_TxnidMostBits  = uint64(0)
)

Default values for CommandAddSubscriptionToTxn fields.

View Source
const (
	Default_CommandAddSubscriptionToTxnResponse_TxnidLeastBits = uint64(0)
	Default_CommandAddSubscriptionToTxnResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandAddSubscriptionToTxnResponse fields.

View Source
const (
	Default_CommandEndTxn_TxnidLeastBits = uint64(0)
	Default_CommandEndTxn_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxn fields.

View Source
const (
	Default_CommandEndTxnResponse_TxnidLeastBits = uint64(0)
	Default_CommandEndTxnResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxnResponse fields.

View Source
const (
	Default_CommandEndTxnOnPartition_TxnidLeastBits = uint64(0)
	Default_CommandEndTxnOnPartition_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxnOnPartition fields.

View Source
const (
	Default_CommandEndTxnOnPartitionResponse_TxnidLeastBits = uint64(0)
	Default_CommandEndTxnOnPartitionResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxnOnPartitionResponse fields.

View Source
const (
	Default_CommandEndTxnOnSubscription_TxnidLeastBits = uint64(0)
	Default_CommandEndTxnOnSubscription_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxnOnSubscription fields.

View Source
const (
	Default_CommandEndTxnOnSubscriptionResponse_TxnidLeastBits = uint64(0)
	Default_CommandEndTxnOnSubscriptionResponse_TxnidMostBits  = uint64(0)
)

Default values for CommandEndTxnOnSubscriptionResponse fields.

View Source
const (
	Default_CommandActiveConsumerChange_IsActive = bool(false)
)

Default values for CommandActiveConsumerChange fields.

View Source
const (
	Default_CommandAuthChallenge_ProtocolVersion = int32(0)
)

Default values for CommandAuthChallenge fields.

View Source
const (
	Default_CommandAuthResponse_ProtocolVersion = int32(0)
)

Default values for CommandAuthResponse fields.

View Source
const (
	Default_CommandConnect_ProtocolVersion = int32(0)
)

Default values for CommandConnect fields.

View Source
const (
	Default_CommandConnected_ProtocolVersion = int32(0)
)

Default values for CommandConnected fields.

View Source
const (
	Default_CommandGetTopicsOfNamespace_Mode = CommandGetTopicsOfNamespace_PERSISTENT
)

Default values for CommandGetTopicsOfNamespace fields.

View Source
const (
	Default_CommandLookupTopic_Authoritative = bool(false)
)

Default values for CommandLookupTopic fields.

View Source
const (
	Default_CommandMessage_RedeliveryCount = uint32(0)
)

Default values for CommandMessage fields.

View Source
const (
	Default_CommandSendReceipt_HighestSequenceId = uint64(0)
)

Default values for CommandSendReceipt fields.

View Source
const (
	Default_CommandTcClientConnectRequest_TcId = uint64(0)
)

Default values for CommandTcClientConnectRequest fields.

View Source
const (
	Default_KeySharedMeta_AllowOutOfOrderDelivery = bool(false)
)

Default values for KeySharedMeta fields.

Variables

View Source
var (
	CompressionType_name = map[int32]string{
		0: "NONE",
		1: "LZ4",
		2: "ZLIB",
		3: "ZSTD",
		4: "SNAPPY",
	}
	CompressionType_value = map[string]int32{
		"NONE":   0,
		"LZ4":    1,
		"ZLIB":   2,
		"ZSTD":   3,
		"SNAPPY": 4,
	}
)

Enum value maps for CompressionType.

View Source
var (
	ProducerAccessMode_name = map[int32]string{
		0: "Shared",
		1: "Exclusive",
		2: "WaitForExclusive",
		3: "ExclusiveWithFencing",
	}
	ProducerAccessMode_value = map[string]int32{
		"Shared":               0,
		"Exclusive":            1,
		"WaitForExclusive":     2,
		"ExclusiveWithFencing": 3,
	}
)

Enum value maps for ProducerAccessMode.

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",
		22: "NotAllowedError",
		23: "TransactionConflict",
		24: "TransactionNotFound",
		25: "ProducerFenced",
	}
	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,
		"NotAllowedError":                       22,
		"TransactionConflict":                   23,
		"TransactionNotFound":                   24,
		"ProducerFenced":                        25,
	}
)

Enum value maps for ServerError.

View Source
var (
	AuthMethod_name = map[int32]string{
		0: "AuthMethodNone",
		1: "AuthMethodYcaV1",
		2: "AuthMethodAthens",
	}
	AuthMethod_value = map[string]int32{
		"AuthMethodNone":   0,
		"AuthMethodYcaV1":  1,
		"AuthMethodAthens": 2,
	}
)

Enum value maps for AuthMethod.

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",
		16: "v16",
		17: "v17",
		18: "v18",
		19: "v19",
	}
	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,
		"v16": 16,
		"v17": 17,
		"v18": 18,
		"v19": 19,
	}
)

Enum value maps for ProtocolVersion.

View Source
var (
	KeySharedMode_name = map[int32]string{
		0: "AUTO_SPLIT",
		1: "STICKY",
	}
	KeySharedMode_value = map[string]int32{
		"AUTO_SPLIT": 0,
		"STICKY":     1,
	}
)

Enum value maps for KeySharedMode.

View Source
var (
	TxnAction_name = map[int32]string{
		0: "COMMIT",
		1: "ABORT",
	}
	TxnAction_value = map[string]int32{
		"COMMIT": 0,
		"ABORT":  1,
	}
)

Enum value maps for TxnAction.

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",
		16: "Instant",
		17: "LocalDate",
		18: "LocalTime",
		19: "LocalDateTime",
		20: "ProtobufNative",
	}
	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,
		"Instant":        16,
		"LocalDate":      17,
		"LocalTime":      18,
		"LocalDateTime":  19,
		"ProtobufNative": 20,
	}
)

Enum value maps for Schema_Type.

View Source
var (
	CommandSubscribe_SubType_name = map[int32]string{
		0: "Exclusive",
		1: "Shared",
		2: "Failover",
		3: "Key_Shared",
	}
	CommandSubscribe_SubType_value = map[string]int32{
		"Exclusive":  0,
		"Shared":     1,
		"Failover":   2,
		"Key_Shared": 3,
	}
)

Enum value maps for CommandSubscribe_SubType.

View Source
var (
	CommandSubscribe_InitialPosition_name = map[int32]string{
		0: "Latest",
		1: "Earliest",
	}
	CommandSubscribe_InitialPosition_value = map[string]int32{
		"Latest":   0,
		"Earliest": 1,
	}
)

Enum value maps for CommandSubscribe_InitialPosition.

View Source
var (
	CommandPartitionedTopicMetadataResponse_LookupType_name = map[int32]string{
		0: "Success",
		1: "Failed",
	}
	CommandPartitionedTopicMetadataResponse_LookupType_value = map[string]int32{
		"Success": 0,
		"Failed":  1,
	}
)

Enum value maps for CommandPartitionedTopicMetadataResponse_LookupType.

View Source
var (
	CommandLookupTopicResponse_LookupType_name = map[int32]string{
		0: "Redirect",
		1: "Connect",
		2: "Failed",
	}
	CommandLookupTopicResponse_LookupType_value = map[string]int32{
		"Redirect": 0,
		"Connect":  1,
		"Failed":   2,
	}
)

Enum value maps for CommandLookupTopicResponse_LookupType.

View Source
var (
	CommandAck_AckType_name = map[int32]string{
		0: "Individual",
		1: "Cumulative",
	}
	CommandAck_AckType_value = map[string]int32{
		"Individual": 0,
		"Cumulative": 1,
	}
)

Enum value maps for CommandAck_AckType.

View Source
var (
	CommandAck_ValidationError_name = map[int32]string{
		0: "UncompressedSizeCorruption",
		1: "DecompressionError",
		2: "ChecksumMismatch",
		3: "BatchDeSerializeError",
		4: "DecryptionError",
	}
	CommandAck_ValidationError_value = map[string]int32{
		"UncompressedSizeCorruption": 0,
		"DecompressionError":         1,
		"ChecksumMismatch":           2,
		"BatchDeSerializeError":      3,
		"DecryptionError":            4,
	}
)

Enum value maps for CommandAck_ValidationError.

View Source
var (
	CommandGetTopicsOfNamespace_Mode_name = map[int32]string{
		0: "PERSISTENT",
		1: "NON_PERSISTENT",
		2: "ALL",
	}
	CommandGetTopicsOfNamespace_Mode_value = map[string]int32{
		"PERSISTENT":     0,
		"NON_PERSISTENT": 1,
		"ALL":            2,
	}
)

Enum value maps for CommandGetTopicsOfNamespace_Mode.

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",
		62: "TC_CLIENT_CONNECT_REQUEST",
		63: "TC_CLIENT_CONNECT_RESPONSE",
		64: "WATCH_TOPIC_LIST",
		65: "WATCH_TOPIC_LIST_SUCCESS",
		66: "WATCH_TOPIC_UPDATE",
		67: "WATCH_TOPIC_LIST_CLOSE",
	}
	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,
		"TC_CLIENT_CONNECT_REQUEST":         62,
		"TC_CLIENT_CONNECT_RESPONSE":        63,
		"WATCH_TOPIC_LIST":                  64,
		"WATCH_TOPIC_LIST_SUCCESS":          65,
		"WATCH_TOPIC_UPDATE":                66,
		"WATCH_TOPIC_LIST_CLOSE":            67,
	}
)

Enum value maps for BaseCommand_Type.

View Source
var File_PulsarApi_proto protoreflect.FileDescriptor

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"`
	// contains filtered or unexported fields
}

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

func (*AuthData) Descriptor deprecated

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

Deprecated: Use AuthData.ProtoReflect.Descriptor instead.

func (*AuthData) GetAuthData

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

func (*AuthData) GetAuthMethodName

func (x *AuthData) GetAuthMethodName() string

func (*AuthData) ProtoMessage

func (*AuthData) ProtoMessage()

func (*AuthData) ProtoReflect added in v0.10.0

func (x *AuthData) ProtoReflect() protoreflect.Message

func (*AuthData) Reset

func (x *AuthData) Reset()

func (*AuthData) String

func (x *AuthData) String() string

type AuthMethod

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

func (AuthMethod) Descriptor added in v0.10.0

func (AuthMethod) Descriptor() protoreflect.EnumDescriptor

func (AuthMethod) Enum

func (x AuthMethod) Enum() *AuthMethod

func (AuthMethod) EnumDescriptor deprecated

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

Deprecated: Use AuthMethod.Descriptor instead.

func (AuthMethod) Number added in v0.10.0

func (x AuthMethod) Number() protoreflect.EnumNumber

func (AuthMethod) String

func (x AuthMethod) String() string

func (AuthMethod) Type added in v0.10.0

func (*AuthMethod) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	TcClientConnectRequest       *CommandTcClientConnectRequest       `protobuf:"bytes,62,opt,name=tcClientConnectRequest" json:"tcClientConnectRequest,omitempty"`
	TcClientConnectResponse      *CommandTcClientConnectResponse      `protobuf:"bytes,63,opt,name=tcClientConnectResponse" json:"tcClientConnectResponse,omitempty"`
	WatchTopicList               *CommandWatchTopicList               `protobuf:"bytes,64,opt,name=watchTopicList" json:"watchTopicList,omitempty"`
	WatchTopicListSuccess        *CommandWatchTopicListSuccess        `protobuf:"bytes,65,opt,name=watchTopicListSuccess" json:"watchTopicListSuccess,omitempty"`
	WatchTopicUpdate             *CommandWatchTopicUpdate             `protobuf:"bytes,66,opt,name=watchTopicUpdate" json:"watchTopicUpdate,omitempty"`
	WatchTopicListClose          *CommandWatchTopicListClose          `protobuf:"bytes,67,opt,name=watchTopicListClose" json:"watchTopicListClose,omitempty"`
	// contains filtered or unexported fields
}

func (*BaseCommand) Descriptor deprecated

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

Deprecated: Use BaseCommand.ProtoReflect.Descriptor instead.

func (*BaseCommand) GetAck

func (x *BaseCommand) GetAck() *CommandAck

func (*BaseCommand) GetAckResponse

func (x *BaseCommand) GetAckResponse() *CommandAckResponse

func (*BaseCommand) GetActiveConsumerChange

func (x *BaseCommand) GetActiveConsumerChange() *CommandActiveConsumerChange

func (*BaseCommand) GetAddPartitionToTxn

func (x *BaseCommand) GetAddPartitionToTxn() *CommandAddPartitionToTxn

func (*BaseCommand) GetAddPartitionToTxnResponse

func (x *BaseCommand) GetAddPartitionToTxnResponse() *CommandAddPartitionToTxnResponse

func (*BaseCommand) GetAddSubscriptionToTxn

func (x *BaseCommand) GetAddSubscriptionToTxn() *CommandAddSubscriptionToTxn

func (*BaseCommand) GetAddSubscriptionToTxnResponse

func (x *BaseCommand) GetAddSubscriptionToTxnResponse() *CommandAddSubscriptionToTxnResponse

func (*BaseCommand) GetAuthChallenge

func (x *BaseCommand) GetAuthChallenge() *CommandAuthChallenge

func (*BaseCommand) GetAuthResponse

func (x *BaseCommand) GetAuthResponse() *CommandAuthResponse

func (*BaseCommand) GetCloseConsumer

func (x *BaseCommand) GetCloseConsumer() *CommandCloseConsumer

func (*BaseCommand) GetCloseProducer

func (x *BaseCommand) GetCloseProducer() *CommandCloseProducer

func (*BaseCommand) GetConnect

func (x *BaseCommand) GetConnect() *CommandConnect

func (*BaseCommand) GetConnected

func (x *BaseCommand) GetConnected() *CommandConnected

func (*BaseCommand) GetConsumerStats

func (x *BaseCommand) GetConsumerStats() *CommandConsumerStats

func (*BaseCommand) GetConsumerStatsResponse

func (x *BaseCommand) GetConsumerStatsResponse() *CommandConsumerStatsResponse

func (*BaseCommand) GetEndTxn

func (x *BaseCommand) GetEndTxn() *CommandEndTxn

func (*BaseCommand) GetEndTxnOnPartition

func (x *BaseCommand) GetEndTxnOnPartition() *CommandEndTxnOnPartition

func (*BaseCommand) GetEndTxnOnPartitionResponse

func (x *BaseCommand) GetEndTxnOnPartitionResponse() *CommandEndTxnOnPartitionResponse

func (*BaseCommand) GetEndTxnOnSubscription

func (x *BaseCommand) GetEndTxnOnSubscription() *CommandEndTxnOnSubscription

func (*BaseCommand) GetEndTxnOnSubscriptionResponse

func (x *BaseCommand) GetEndTxnOnSubscriptionResponse() *CommandEndTxnOnSubscriptionResponse

func (*BaseCommand) GetEndTxnResponse

func (x *BaseCommand) GetEndTxnResponse() *CommandEndTxnResponse

func (*BaseCommand) GetError

func (x *BaseCommand) GetError() *CommandError

func (*BaseCommand) GetFlow

func (x *BaseCommand) GetFlow() *CommandFlow

func (*BaseCommand) GetGetLastMessageId

func (x *BaseCommand) GetGetLastMessageId() *CommandGetLastMessageId

func (*BaseCommand) GetGetLastMessageIdResponse

func (x *BaseCommand) GetGetLastMessageIdResponse() *CommandGetLastMessageIdResponse

func (*BaseCommand) GetGetOrCreateSchema

func (x *BaseCommand) GetGetOrCreateSchema() *CommandGetOrCreateSchema

func (*BaseCommand) GetGetOrCreateSchemaResponse

func (x *BaseCommand) GetGetOrCreateSchemaResponse() *CommandGetOrCreateSchemaResponse

func (*BaseCommand) GetGetSchema

func (x *BaseCommand) GetGetSchema() *CommandGetSchema

func (*BaseCommand) GetGetSchemaResponse

func (x *BaseCommand) GetGetSchemaResponse() *CommandGetSchemaResponse

func (*BaseCommand) GetGetTopicsOfNamespace

func (x *BaseCommand) GetGetTopicsOfNamespace() *CommandGetTopicsOfNamespace

func (*BaseCommand) GetGetTopicsOfNamespaceResponse

func (x *BaseCommand) GetGetTopicsOfNamespaceResponse() *CommandGetTopicsOfNamespaceResponse

func (*BaseCommand) GetLookupTopic

func (x *BaseCommand) GetLookupTopic() *CommandLookupTopic

func (*BaseCommand) GetLookupTopicResponse

func (x *BaseCommand) GetLookupTopicResponse() *CommandLookupTopicResponse

func (*BaseCommand) GetMessage

func (x *BaseCommand) GetMessage() *CommandMessage

func (*BaseCommand) GetNewTxn

func (x *BaseCommand) GetNewTxn() *CommandNewTxn

func (*BaseCommand) GetNewTxnResponse

func (x *BaseCommand) GetNewTxnResponse() *CommandNewTxnResponse

func (*BaseCommand) GetPartitionMetadata

func (x *BaseCommand) GetPartitionMetadata() *CommandPartitionedTopicMetadata

func (*BaseCommand) GetPartitionMetadataResponse

func (x *BaseCommand) GetPartitionMetadataResponse() *CommandPartitionedTopicMetadataResponse

func (*BaseCommand) GetPing

func (x *BaseCommand) GetPing() *CommandPing

func (*BaseCommand) GetPong

func (x *BaseCommand) GetPong() *CommandPong

func (*BaseCommand) GetProducer

func (x *BaseCommand) GetProducer() *CommandProducer

func (*BaseCommand) GetProducerSuccess

func (x *BaseCommand) GetProducerSuccess() *CommandProducerSuccess

func (*BaseCommand) GetReachedEndOfTopic

func (x *BaseCommand) GetReachedEndOfTopic() *CommandReachedEndOfTopic

func (*BaseCommand) GetRedeliverUnacknowledgedMessages

func (x *BaseCommand) GetRedeliverUnacknowledgedMessages() *CommandRedeliverUnacknowledgedMessages

func (*BaseCommand) GetSeek

func (x *BaseCommand) GetSeek() *CommandSeek

func (*BaseCommand) GetSend

func (x *BaseCommand) GetSend() *CommandSend

func (*BaseCommand) GetSendError

func (x *BaseCommand) GetSendError() *CommandSendError

func (*BaseCommand) GetSendReceipt

func (x *BaseCommand) GetSendReceipt() *CommandSendReceipt

func (*BaseCommand) GetSubscribe

func (x *BaseCommand) GetSubscribe() *CommandSubscribe

func (*BaseCommand) GetSuccess

func (x *BaseCommand) GetSuccess() *CommandSuccess

func (*BaseCommand) GetTcClientConnectRequest added in v0.8.0

func (x *BaseCommand) GetTcClientConnectRequest() *CommandTcClientConnectRequest

func (*BaseCommand) GetTcClientConnectResponse added in v0.8.0

func (x *BaseCommand) GetTcClientConnectResponse() *CommandTcClientConnectResponse

func (*BaseCommand) GetType

func (x *BaseCommand) GetType() BaseCommand_Type

func (*BaseCommand) GetUnsubscribe

func (x *BaseCommand) GetUnsubscribe() *CommandUnsubscribe

func (*BaseCommand) GetWatchTopicList added in v0.9.0

func (x *BaseCommand) GetWatchTopicList() *CommandWatchTopicList

func (*BaseCommand) GetWatchTopicListClose added in v0.9.0

func (x *BaseCommand) GetWatchTopicListClose() *CommandWatchTopicListClose

func (*BaseCommand) GetWatchTopicListSuccess added in v0.9.0

func (x *BaseCommand) GetWatchTopicListSuccess() *CommandWatchTopicListSuccess

func (*BaseCommand) GetWatchTopicUpdate added in v0.9.0

func (x *BaseCommand) GetWatchTopicUpdate() *CommandWatchTopicUpdate

func (*BaseCommand) ProtoMessage

func (*BaseCommand) ProtoMessage()

func (*BaseCommand) ProtoReflect added in v0.10.0

func (x *BaseCommand) ProtoReflect() protoreflect.Message

func (*BaseCommand) Reset

func (x *BaseCommand) Reset()

func (*BaseCommand) String

func (x *BaseCommand) String() string

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
	BaseCommand_TC_CLIENT_CONNECT_REQUEST        BaseCommand_Type = 62
	BaseCommand_TC_CLIENT_CONNECT_RESPONSE       BaseCommand_Type = 63
	BaseCommand_WATCH_TOPIC_LIST                 BaseCommand_Type = 64
	BaseCommand_WATCH_TOPIC_LIST_SUCCESS         BaseCommand_Type = 65
	BaseCommand_WATCH_TOPIC_UPDATE               BaseCommand_Type = 66
	BaseCommand_WATCH_TOPIC_LIST_CLOSE           BaseCommand_Type = 67
)

func (BaseCommand_Type) Descriptor added in v0.10.0

func (BaseCommand_Type) Enum

func (BaseCommand_Type) EnumDescriptor deprecated

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

Deprecated: Use BaseCommand_Type.Descriptor instead.

func (BaseCommand_Type) Number added in v0.10.0

func (BaseCommand_Type) String

func (x BaseCommand_Type) String() string

func (BaseCommand_Type) Type added in v0.10.0

func (*BaseCommand_Type) UnmarshalJSON deprecated

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

Deprecated: Do not use.

type BrokerEntryMetadata added in v0.6.0

type BrokerEntryMetadata struct {
	BrokerTimestamp *uint64 `protobuf:"varint,1,opt,name=broker_timestamp,json=brokerTimestamp" json:"broker_timestamp,omitempty"`
	Index           *uint64 `protobuf:"varint,2,opt,name=index" json:"index,omitempty"`
	// contains filtered or unexported fields
}

metadata added for entry from broker

func (*BrokerEntryMetadata) Descriptor deprecated added in v0.6.0

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

Deprecated: Use BrokerEntryMetadata.ProtoReflect.Descriptor instead.

func (*BrokerEntryMetadata) GetBrokerTimestamp added in v0.6.0

func (x *BrokerEntryMetadata) GetBrokerTimestamp() uint64

func (*BrokerEntryMetadata) GetIndex added in v0.6.0

func (x *BrokerEntryMetadata) GetIndex() uint64

func (*BrokerEntryMetadata) ProtoMessage added in v0.6.0

func (*BrokerEntryMetadata) ProtoMessage()

func (*BrokerEntryMetadata) ProtoReflect added in v0.10.0

func (x *BrokerEntryMetadata) ProtoReflect() protoreflect.Message

func (*BrokerEntryMetadata) Reset added in v0.6.0

func (x *BrokerEntryMetadata) Reset()

func (*BrokerEntryMetadata) String added in v0.6.0

func (x *BrokerEntryMetadata) String() string

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"`
	RequestId       *uint64                     `protobuf:"varint,8,opt,name=request_id,json=requestId" json:"request_id,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandAck) Descriptor deprecated

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

Deprecated: Use CommandAck.ProtoReflect.Descriptor instead.

func (*CommandAck) GetAckType

func (x *CommandAck) GetAckType() CommandAck_AckType

func (*CommandAck) GetConsumerId

func (x *CommandAck) GetConsumerId() uint64

func (*CommandAck) GetMessageId

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

func (*CommandAck) GetProperties

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

func (*CommandAck) GetRequestId added in v0.6.0

func (x *CommandAck) GetRequestId() uint64

func (*CommandAck) GetTxnidLeastBits

func (x *CommandAck) GetTxnidLeastBits() uint64

func (*CommandAck) GetTxnidMostBits

func (x *CommandAck) GetTxnidMostBits() uint64

func (*CommandAck) GetValidationError

func (x *CommandAck) GetValidationError() CommandAck_ValidationError

func (*CommandAck) ProtoMessage

func (*CommandAck) ProtoMessage()

func (*CommandAck) ProtoReflect added in v0.10.0

func (x *CommandAck) ProtoReflect() protoreflect.Message

func (*CommandAck) Reset

func (x *CommandAck) Reset()

func (*CommandAck) String

func (x *CommandAck) String() string

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"`
	RequestId      *uint64      `protobuf:"varint,6,opt,name=request_id,json=requestId" json:"request_id,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandAckResponse) Descriptor deprecated

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

Deprecated: Use CommandAckResponse.ProtoReflect.Descriptor instead.

func (*CommandAckResponse) GetConsumerId

func (x *CommandAckResponse) GetConsumerId() uint64

func (*CommandAckResponse) GetError

func (x *CommandAckResponse) GetError() ServerError

func (*CommandAckResponse) GetMessage

func (x *CommandAckResponse) GetMessage() string

func (*CommandAckResponse) GetRequestId added in v0.6.0

func (x *CommandAckResponse) GetRequestId() uint64

func (*CommandAckResponse) GetTxnidLeastBits

func (x *CommandAckResponse) GetTxnidLeastBits() uint64

func (*CommandAckResponse) GetTxnidMostBits

func (x *CommandAckResponse) GetTxnidMostBits() uint64

func (*CommandAckResponse) ProtoMessage

func (*CommandAckResponse) ProtoMessage()

func (*CommandAckResponse) ProtoReflect added in v0.10.0

func (x *CommandAckResponse) ProtoReflect() protoreflect.Message

func (*CommandAckResponse) Reset

func (x *CommandAckResponse) Reset()

func (*CommandAckResponse) String

func (x *CommandAckResponse) String() string

type CommandAck_AckType

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

func (CommandAck_AckType) Descriptor added in v0.10.0

func (CommandAck_AckType) Enum

func (CommandAck_AckType) EnumDescriptor deprecated

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

Deprecated: Use CommandAck_AckType.Descriptor instead.

func (CommandAck_AckType) Number added in v0.10.0

func (CommandAck_AckType) String

func (x CommandAck_AckType) String() string

func (CommandAck_AckType) Type added in v0.10.0

func (*CommandAck_AckType) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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) Descriptor added in v0.10.0

func (CommandAck_ValidationError) Enum

func (CommandAck_ValidationError) EnumDescriptor deprecated

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

Deprecated: Use CommandAck_ValidationError.Descriptor instead.

func (CommandAck_ValidationError) Number added in v0.10.0

func (CommandAck_ValidationError) String

func (CommandAck_ValidationError) Type added in v0.10.0

func (*CommandAck_ValidationError) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// contains filtered or unexported fields
}

changes on active consumer

func (*CommandActiveConsumerChange) Descriptor deprecated

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

Deprecated: Use CommandActiveConsumerChange.ProtoReflect.Descriptor instead.

func (*CommandActiveConsumerChange) GetConsumerId

func (x *CommandActiveConsumerChange) GetConsumerId() uint64

func (*CommandActiveConsumerChange) GetIsActive

func (x *CommandActiveConsumerChange) GetIsActive() bool

func (*CommandActiveConsumerChange) ProtoMessage

func (*CommandActiveConsumerChange) ProtoMessage()

func (*CommandActiveConsumerChange) ProtoReflect added in v0.10.0

func (*CommandActiveConsumerChange) Reset

func (x *CommandActiveConsumerChange) Reset()

func (*CommandActiveConsumerChange) String

func (x *CommandActiveConsumerChange) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandAddPartitionToTxn) Descriptor deprecated

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

Deprecated: Use CommandAddPartitionToTxn.ProtoReflect.Descriptor instead.

func (*CommandAddPartitionToTxn) GetPartitions

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

func (*CommandAddPartitionToTxn) GetRequestId

func (x *CommandAddPartitionToTxn) GetRequestId() uint64

func (*CommandAddPartitionToTxn) GetTxnidLeastBits

func (x *CommandAddPartitionToTxn) GetTxnidLeastBits() uint64

func (*CommandAddPartitionToTxn) GetTxnidMostBits

func (x *CommandAddPartitionToTxn) GetTxnidMostBits() uint64

func (*CommandAddPartitionToTxn) ProtoMessage

func (*CommandAddPartitionToTxn) ProtoMessage()

func (*CommandAddPartitionToTxn) ProtoReflect added in v0.10.0

func (x *CommandAddPartitionToTxn) ProtoReflect() protoreflect.Message

func (*CommandAddPartitionToTxn) Reset

func (x *CommandAddPartitionToTxn) Reset()

func (*CommandAddPartitionToTxn) String

func (x *CommandAddPartitionToTxn) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandAddPartitionToTxnResponse) Descriptor deprecated

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

Deprecated: Use CommandAddPartitionToTxnResponse.ProtoReflect.Descriptor instead.

func (*CommandAddPartitionToTxnResponse) GetError

func (*CommandAddPartitionToTxnResponse) GetMessage

func (x *CommandAddPartitionToTxnResponse) GetMessage() string

func (*CommandAddPartitionToTxnResponse) GetRequestId

func (x *CommandAddPartitionToTxnResponse) GetRequestId() uint64

func (*CommandAddPartitionToTxnResponse) GetTxnidLeastBits

func (x *CommandAddPartitionToTxnResponse) GetTxnidLeastBits() uint64

func (*CommandAddPartitionToTxnResponse) GetTxnidMostBits

func (x *CommandAddPartitionToTxnResponse) GetTxnidMostBits() uint64

func (*CommandAddPartitionToTxnResponse) ProtoMessage

func (*CommandAddPartitionToTxnResponse) ProtoMessage()

func (*CommandAddPartitionToTxnResponse) ProtoReflect added in v0.10.0

func (*CommandAddPartitionToTxnResponse) Reset

func (*CommandAddPartitionToTxnResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandAddSubscriptionToTxn) Descriptor deprecated

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

Deprecated: Use CommandAddSubscriptionToTxn.ProtoReflect.Descriptor instead.

func (*CommandAddSubscriptionToTxn) GetRequestId

func (x *CommandAddSubscriptionToTxn) GetRequestId() uint64

func (*CommandAddSubscriptionToTxn) GetSubscription

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

func (*CommandAddSubscriptionToTxn) GetTxnidLeastBits

func (x *CommandAddSubscriptionToTxn) GetTxnidLeastBits() uint64

func (*CommandAddSubscriptionToTxn) GetTxnidMostBits

func (x *CommandAddSubscriptionToTxn) GetTxnidMostBits() uint64

func (*CommandAddSubscriptionToTxn) ProtoMessage

func (*CommandAddSubscriptionToTxn) ProtoMessage()

func (*CommandAddSubscriptionToTxn) ProtoReflect added in v0.10.0

func (*CommandAddSubscriptionToTxn) Reset

func (x *CommandAddSubscriptionToTxn) Reset()

func (*CommandAddSubscriptionToTxn) String

func (x *CommandAddSubscriptionToTxn) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandAddSubscriptionToTxnResponse) Descriptor deprecated

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

Deprecated: Use CommandAddSubscriptionToTxnResponse.ProtoReflect.Descriptor instead.

func (*CommandAddSubscriptionToTxnResponse) GetError

func (*CommandAddSubscriptionToTxnResponse) GetMessage

func (*CommandAddSubscriptionToTxnResponse) GetRequestId

func (x *CommandAddSubscriptionToTxnResponse) GetRequestId() uint64

func (*CommandAddSubscriptionToTxnResponse) GetTxnidLeastBits

func (x *CommandAddSubscriptionToTxnResponse) GetTxnidLeastBits() uint64

func (*CommandAddSubscriptionToTxnResponse) GetTxnidMostBits

func (x *CommandAddSubscriptionToTxnResponse) GetTxnidMostBits() uint64

func (*CommandAddSubscriptionToTxnResponse) ProtoMessage

func (*CommandAddSubscriptionToTxnResponse) ProtoMessage()

func (*CommandAddSubscriptionToTxnResponse) ProtoReflect added in v0.10.0

func (*CommandAddSubscriptionToTxnResponse) Reset

func (*CommandAddSubscriptionToTxnResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandAuthChallenge) Descriptor deprecated

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

Deprecated: Use CommandAuthChallenge.ProtoReflect.Descriptor instead.

func (*CommandAuthChallenge) GetChallenge

func (x *CommandAuthChallenge) GetChallenge() *AuthData

func (*CommandAuthChallenge) GetProtocolVersion

func (x *CommandAuthChallenge) GetProtocolVersion() int32

func (*CommandAuthChallenge) GetServerVersion

func (x *CommandAuthChallenge) GetServerVersion() string

func (*CommandAuthChallenge) ProtoMessage

func (*CommandAuthChallenge) ProtoMessage()

func (*CommandAuthChallenge) ProtoReflect added in v0.10.0

func (x *CommandAuthChallenge) ProtoReflect() protoreflect.Message

func (*CommandAuthChallenge) Reset

func (x *CommandAuthChallenge) Reset()

func (*CommandAuthChallenge) String

func (x *CommandAuthChallenge) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandAuthResponse) Descriptor deprecated

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

Deprecated: Use CommandAuthResponse.ProtoReflect.Descriptor instead.

func (*CommandAuthResponse) GetClientVersion

func (x *CommandAuthResponse) GetClientVersion() string

func (*CommandAuthResponse) GetProtocolVersion

func (x *CommandAuthResponse) GetProtocolVersion() int32

func (*CommandAuthResponse) GetResponse

func (x *CommandAuthResponse) GetResponse() *AuthData

func (*CommandAuthResponse) ProtoMessage

func (*CommandAuthResponse) ProtoMessage()

func (*CommandAuthResponse) ProtoReflect added in v0.10.0

func (x *CommandAuthResponse) ProtoReflect() protoreflect.Message

func (*CommandAuthResponse) Reset

func (x *CommandAuthResponse) Reset()

func (*CommandAuthResponse) String

func (x *CommandAuthResponse) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandCloseConsumer) Descriptor deprecated

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

Deprecated: Use CommandCloseConsumer.ProtoReflect.Descriptor instead.

func (*CommandCloseConsumer) GetConsumerId

func (x *CommandCloseConsumer) GetConsumerId() uint64

func (*CommandCloseConsumer) GetRequestId

func (x *CommandCloseConsumer) GetRequestId() uint64

func (*CommandCloseConsumer) ProtoMessage

func (*CommandCloseConsumer) ProtoMessage()

func (*CommandCloseConsumer) ProtoReflect added in v0.10.0

func (x *CommandCloseConsumer) ProtoReflect() protoreflect.Message

func (*CommandCloseConsumer) Reset

func (x *CommandCloseConsumer) Reset()

func (*CommandCloseConsumer) String

func (x *CommandCloseConsumer) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandCloseProducer) Descriptor deprecated

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

Deprecated: Use CommandCloseProducer.ProtoReflect.Descriptor instead.

func (*CommandCloseProducer) GetProducerId

func (x *CommandCloseProducer) GetProducerId() uint64

func (*CommandCloseProducer) GetRequestId

func (x *CommandCloseProducer) GetRequestId() uint64

func (*CommandCloseProducer) ProtoMessage

func (*CommandCloseProducer) ProtoMessage()

func (*CommandCloseProducer) ProtoReflect added in v0.10.0

func (x *CommandCloseProducer) ProtoReflect() protoreflect.Message

func (*CommandCloseProducer) Reset

func (x *CommandCloseProducer) Reset()

func (*CommandCloseProducer) String

func (x *CommandCloseProducer) String() string

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"` // Deprecated. Use "auth_method_name" instead.
	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"`
	// Feature flags
	FeatureFlags *FeatureFlags `protobuf:"bytes,10,opt,name=feature_flags,json=featureFlags" json:"feature_flags,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandConnect) Descriptor deprecated

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

Deprecated: Use CommandConnect.ProtoReflect.Descriptor instead.

func (*CommandConnect) GetAuthData

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

func (*CommandConnect) GetAuthMethod

func (x *CommandConnect) GetAuthMethod() AuthMethod

func (*CommandConnect) GetAuthMethodName

func (x *CommandConnect) GetAuthMethodName() string

func (*CommandConnect) GetClientVersion

func (x *CommandConnect) GetClientVersion() string

func (*CommandConnect) GetFeatureFlags

func (x *CommandConnect) GetFeatureFlags() *FeatureFlags

func (*CommandConnect) GetOriginalAuthData

func (x *CommandConnect) GetOriginalAuthData() string

func (*CommandConnect) GetOriginalAuthMethod

func (x *CommandConnect) GetOriginalAuthMethod() string

func (*CommandConnect) GetOriginalPrincipal

func (x *CommandConnect) GetOriginalPrincipal() string

func (*CommandConnect) GetProtocolVersion

func (x *CommandConnect) GetProtocolVersion() int32

func (*CommandConnect) GetProxyToBrokerUrl

func (x *CommandConnect) GetProxyToBrokerUrl() string

func (*CommandConnect) ProtoMessage

func (*CommandConnect) ProtoMessage()

func (*CommandConnect) ProtoReflect added in v0.10.0

func (x *CommandConnect) ProtoReflect() protoreflect.Message

func (*CommandConnect) Reset

func (x *CommandConnect) Reset()

func (*CommandConnect) String

func (x *CommandConnect) String() string

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"`
	FeatureFlags    *FeatureFlags `protobuf:"bytes,4,opt,name=feature_flags,json=featureFlags" json:"feature_flags,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandConnected) Descriptor deprecated

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

Deprecated: Use CommandConnected.ProtoReflect.Descriptor instead.

func (*CommandConnected) GetFeatureFlags added in v0.9.0

func (x *CommandConnected) GetFeatureFlags() *FeatureFlags

func (*CommandConnected) GetMaxMessageSize

func (x *CommandConnected) GetMaxMessageSize() int32

func (*CommandConnected) GetProtocolVersion

func (x *CommandConnected) GetProtocolVersion() int32

func (*CommandConnected) GetServerVersion

func (x *CommandConnected) GetServerVersion() string

func (*CommandConnected) ProtoMessage

func (*CommandConnected) ProtoMessage()

func (*CommandConnected) ProtoReflect added in v0.10.0

func (x *CommandConnected) ProtoReflect() protoreflect.Message

func (*CommandConnected) Reset

func (x *CommandConnected) Reset()

func (*CommandConnected) String

func (x *CommandConnected) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandConsumerStats) Descriptor deprecated

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

Deprecated: Use CommandConsumerStats.ProtoReflect.Descriptor instead.

func (*CommandConsumerStats) GetConsumerId

func (x *CommandConsumerStats) GetConsumerId() uint64

func (*CommandConsumerStats) GetRequestId

func (x *CommandConsumerStats) GetRequestId() uint64

func (*CommandConsumerStats) ProtoMessage

func (*CommandConsumerStats) ProtoMessage()

func (*CommandConsumerStats) ProtoReflect added in v0.10.0

func (x *CommandConsumerStats) ProtoReflect() protoreflect.Message

func (*CommandConsumerStats) Reset

func (x *CommandConsumerStats) Reset()

func (*CommandConsumerStats) String

func (x *CommandConsumerStats) String() string

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"`
	/// Total rate of messages ack. msg/s
	MessageAckRate *float64 `protobuf:"fixed64,16,opt,name=messageAckRate" json:"messageAckRate,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandConsumerStatsResponse) Descriptor deprecated

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

Deprecated: Use CommandConsumerStatsResponse.ProtoReflect.Descriptor instead.

func (*CommandConsumerStatsResponse) GetAddress

func (x *CommandConsumerStatsResponse) GetAddress() string

func (*CommandConsumerStatsResponse) GetAvailablePermits

func (x *CommandConsumerStatsResponse) GetAvailablePermits() uint64

func (*CommandConsumerStatsResponse) GetBlockedConsumerOnUnackedMsgs

func (x *CommandConsumerStatsResponse) GetBlockedConsumerOnUnackedMsgs() bool

func (*CommandConsumerStatsResponse) GetConnectedSince

func (x *CommandConsumerStatsResponse) GetConnectedSince() string

func (*CommandConsumerStatsResponse) GetConsumerName

func (x *CommandConsumerStatsResponse) GetConsumerName() string

func (*CommandConsumerStatsResponse) GetErrorCode

func (x *CommandConsumerStatsResponse) GetErrorCode() ServerError

func (*CommandConsumerStatsResponse) GetErrorMessage

func (x *CommandConsumerStatsResponse) GetErrorMessage() string

func (*CommandConsumerStatsResponse) GetMessageAckRate added in v0.9.0

func (x *CommandConsumerStatsResponse) GetMessageAckRate() float64

func (*CommandConsumerStatsResponse) GetMsgBacklog

func (x *CommandConsumerStatsResponse) GetMsgBacklog() uint64

func (*CommandConsumerStatsResponse) GetMsgRateExpired

func (x *CommandConsumerStatsResponse) GetMsgRateExpired() float64

func (*CommandConsumerStatsResponse) GetMsgRateOut

func (x *CommandConsumerStatsResponse) GetMsgRateOut() float64

func (*CommandConsumerStatsResponse) GetMsgRateRedeliver

func (x *CommandConsumerStatsResponse) GetMsgRateRedeliver() float64

func (*CommandConsumerStatsResponse) GetMsgThroughputOut

func (x *CommandConsumerStatsResponse) GetMsgThroughputOut() float64

func (*CommandConsumerStatsResponse) GetRequestId

func (x *CommandConsumerStatsResponse) GetRequestId() uint64

func (*CommandConsumerStatsResponse) GetType

func (x *CommandConsumerStatsResponse) GetType() string

func (*CommandConsumerStatsResponse) GetUnackedMessages

func (x *CommandConsumerStatsResponse) GetUnackedMessages() uint64

func (*CommandConsumerStatsResponse) ProtoMessage

func (*CommandConsumerStatsResponse) ProtoMessage()

func (*CommandConsumerStatsResponse) ProtoReflect added in v0.10.0

func (*CommandConsumerStatsResponse) Reset

func (x *CommandConsumerStatsResponse) Reset()

func (*CommandConsumerStatsResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandEndTxn) Descriptor deprecated

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

Deprecated: Use CommandEndTxn.ProtoReflect.Descriptor instead.

func (*CommandEndTxn) GetRequestId

func (x *CommandEndTxn) GetRequestId() uint64

func (*CommandEndTxn) GetTxnAction

func (x *CommandEndTxn) GetTxnAction() TxnAction

func (*CommandEndTxn) GetTxnidLeastBits

func (x *CommandEndTxn) GetTxnidLeastBits() uint64

func (*CommandEndTxn) GetTxnidMostBits

func (x *CommandEndTxn) GetTxnidMostBits() uint64

func (*CommandEndTxn) ProtoMessage

func (*CommandEndTxn) ProtoMessage()

func (*CommandEndTxn) ProtoReflect added in v0.10.0

func (x *CommandEndTxn) ProtoReflect() protoreflect.Message

func (*CommandEndTxn) Reset

func (x *CommandEndTxn) Reset()

func (*CommandEndTxn) String

func (x *CommandEndTxn) String() string

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"`
	TxnidLeastBitsOfLowWatermark *uint64    `` /* 147-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*CommandEndTxnOnPartition) Descriptor deprecated

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

Deprecated: Use CommandEndTxnOnPartition.ProtoReflect.Descriptor instead.

func (*CommandEndTxnOnPartition) GetRequestId

func (x *CommandEndTxnOnPartition) GetRequestId() uint64

func (*CommandEndTxnOnPartition) GetTopic

func (x *CommandEndTxnOnPartition) GetTopic() string

func (*CommandEndTxnOnPartition) GetTxnAction

func (x *CommandEndTxnOnPartition) GetTxnAction() TxnAction

func (*CommandEndTxnOnPartition) GetTxnidLeastBits

func (x *CommandEndTxnOnPartition) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnPartition) GetTxnidLeastBitsOfLowWatermark added in v0.6.0

func (x *CommandEndTxnOnPartition) GetTxnidLeastBitsOfLowWatermark() uint64

func (*CommandEndTxnOnPartition) GetTxnidMostBits

func (x *CommandEndTxnOnPartition) GetTxnidMostBits() uint64

func (*CommandEndTxnOnPartition) ProtoMessage

func (*CommandEndTxnOnPartition) ProtoMessage()

func (*CommandEndTxnOnPartition) ProtoReflect added in v0.10.0

func (x *CommandEndTxnOnPartition) ProtoReflect() protoreflect.Message

func (*CommandEndTxnOnPartition) Reset

func (x *CommandEndTxnOnPartition) Reset()

func (*CommandEndTxnOnPartition) String

func (x *CommandEndTxnOnPartition) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandEndTxnOnPartitionResponse) Descriptor deprecated

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

Deprecated: Use CommandEndTxnOnPartitionResponse.ProtoReflect.Descriptor instead.

func (*CommandEndTxnOnPartitionResponse) GetError

func (*CommandEndTxnOnPartitionResponse) GetMessage

func (x *CommandEndTxnOnPartitionResponse) GetMessage() string

func (*CommandEndTxnOnPartitionResponse) GetRequestId

func (x *CommandEndTxnOnPartitionResponse) GetRequestId() uint64

func (*CommandEndTxnOnPartitionResponse) GetTxnidLeastBits

func (x *CommandEndTxnOnPartitionResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnPartitionResponse) GetTxnidMostBits

func (x *CommandEndTxnOnPartitionResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnOnPartitionResponse) ProtoMessage

func (*CommandEndTxnOnPartitionResponse) ProtoMessage()

func (*CommandEndTxnOnPartitionResponse) ProtoReflect added in v0.10.0

func (*CommandEndTxnOnPartitionResponse) Reset

func (*CommandEndTxnOnPartitionResponse) String

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"`
	TxnidLeastBitsOfLowWatermark *uint64       `` /* 147-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*CommandEndTxnOnSubscription) Descriptor deprecated

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

Deprecated: Use CommandEndTxnOnSubscription.ProtoReflect.Descriptor instead.

func (*CommandEndTxnOnSubscription) GetRequestId

func (x *CommandEndTxnOnSubscription) GetRequestId() uint64

func (*CommandEndTxnOnSubscription) GetSubscription

func (x *CommandEndTxnOnSubscription) GetSubscription() *Subscription

func (*CommandEndTxnOnSubscription) GetTxnAction

func (x *CommandEndTxnOnSubscription) GetTxnAction() TxnAction

func (*CommandEndTxnOnSubscription) GetTxnidLeastBits

func (x *CommandEndTxnOnSubscription) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnSubscription) GetTxnidLeastBitsOfLowWatermark added in v0.6.0

func (x *CommandEndTxnOnSubscription) GetTxnidLeastBitsOfLowWatermark() uint64

func (*CommandEndTxnOnSubscription) GetTxnidMostBits

func (x *CommandEndTxnOnSubscription) GetTxnidMostBits() uint64

func (*CommandEndTxnOnSubscription) ProtoMessage

func (*CommandEndTxnOnSubscription) ProtoMessage()

func (*CommandEndTxnOnSubscription) ProtoReflect added in v0.10.0

func (*CommandEndTxnOnSubscription) Reset

func (x *CommandEndTxnOnSubscription) Reset()

func (*CommandEndTxnOnSubscription) String

func (x *CommandEndTxnOnSubscription) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandEndTxnOnSubscriptionResponse) Descriptor deprecated

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

Deprecated: Use CommandEndTxnOnSubscriptionResponse.ProtoReflect.Descriptor instead.

func (*CommandEndTxnOnSubscriptionResponse) GetError

func (*CommandEndTxnOnSubscriptionResponse) GetMessage

func (*CommandEndTxnOnSubscriptionResponse) GetRequestId

func (x *CommandEndTxnOnSubscriptionResponse) GetRequestId() uint64

func (*CommandEndTxnOnSubscriptionResponse) GetTxnidLeastBits

func (x *CommandEndTxnOnSubscriptionResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnOnSubscriptionResponse) GetTxnidMostBits

func (x *CommandEndTxnOnSubscriptionResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnOnSubscriptionResponse) ProtoMessage

func (*CommandEndTxnOnSubscriptionResponse) ProtoMessage()

func (*CommandEndTxnOnSubscriptionResponse) ProtoReflect added in v0.10.0

func (*CommandEndTxnOnSubscriptionResponse) Reset

func (*CommandEndTxnOnSubscriptionResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandEndTxnResponse) Descriptor deprecated

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

Deprecated: Use CommandEndTxnResponse.ProtoReflect.Descriptor instead.

func (*CommandEndTxnResponse) GetError

func (x *CommandEndTxnResponse) GetError() ServerError

func (*CommandEndTxnResponse) GetMessage

func (x *CommandEndTxnResponse) GetMessage() string

func (*CommandEndTxnResponse) GetRequestId

func (x *CommandEndTxnResponse) GetRequestId() uint64

func (*CommandEndTxnResponse) GetTxnidLeastBits

func (x *CommandEndTxnResponse) GetTxnidLeastBits() uint64

func (*CommandEndTxnResponse) GetTxnidMostBits

func (x *CommandEndTxnResponse) GetTxnidMostBits() uint64

func (*CommandEndTxnResponse) ProtoMessage

func (*CommandEndTxnResponse) ProtoMessage()

func (*CommandEndTxnResponse) ProtoReflect added in v0.10.0

func (x *CommandEndTxnResponse) ProtoReflect() protoreflect.Message

func (*CommandEndTxnResponse) Reset

func (x *CommandEndTxnResponse) Reset()

func (*CommandEndTxnResponse) String

func (x *CommandEndTxnResponse) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandError) Descriptor deprecated

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

Deprecated: Use CommandError.ProtoReflect.Descriptor instead.

func (*CommandError) GetError

func (x *CommandError) GetError() ServerError

func (*CommandError) GetMessage

func (x *CommandError) GetMessage() string

func (*CommandError) GetRequestId

func (x *CommandError) GetRequestId() uint64

func (*CommandError) ProtoMessage

func (*CommandError) ProtoMessage()

func (*CommandError) ProtoReflect added in v0.10.0

func (x *CommandError) ProtoReflect() protoreflect.Message

func (*CommandError) Reset

func (x *CommandError) Reset()

func (*CommandError) String

func (x *CommandError) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandFlow) Descriptor deprecated

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

Deprecated: Use CommandFlow.ProtoReflect.Descriptor instead.

func (*CommandFlow) GetConsumerId

func (x *CommandFlow) GetConsumerId() uint64

func (*CommandFlow) GetMessagePermits

func (x *CommandFlow) GetMessagePermits() uint32

func (*CommandFlow) ProtoMessage

func (*CommandFlow) ProtoMessage()

func (*CommandFlow) ProtoReflect added in v0.10.0

func (x *CommandFlow) ProtoReflect() protoreflect.Message

func (*CommandFlow) Reset

func (x *CommandFlow) Reset()

func (*CommandFlow) String

func (x *CommandFlow) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandGetLastMessageId) Descriptor deprecated

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

Deprecated: Use CommandGetLastMessageId.ProtoReflect.Descriptor instead.

func (*CommandGetLastMessageId) GetConsumerId

func (x *CommandGetLastMessageId) GetConsumerId() uint64

func (*CommandGetLastMessageId) GetRequestId

func (x *CommandGetLastMessageId) GetRequestId() uint64

func (*CommandGetLastMessageId) ProtoMessage

func (*CommandGetLastMessageId) ProtoMessage()

func (*CommandGetLastMessageId) ProtoReflect added in v0.10.0

func (x *CommandGetLastMessageId) ProtoReflect() protoreflect.Message

func (*CommandGetLastMessageId) Reset

func (x *CommandGetLastMessageId) Reset()

func (*CommandGetLastMessageId) String

func (x *CommandGetLastMessageId) String() string

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"`
	ConsumerMarkDeletePosition *MessageIdData `` /* 136-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*CommandGetLastMessageIdResponse) Descriptor deprecated

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

Deprecated: Use CommandGetLastMessageIdResponse.ProtoReflect.Descriptor instead.

func (*CommandGetLastMessageIdResponse) GetConsumerMarkDeletePosition added in v0.6.0

func (x *CommandGetLastMessageIdResponse) GetConsumerMarkDeletePosition() *MessageIdData

func (*CommandGetLastMessageIdResponse) GetLastMessageId

func (x *CommandGetLastMessageIdResponse) GetLastMessageId() *MessageIdData

func (*CommandGetLastMessageIdResponse) GetRequestId

func (x *CommandGetLastMessageIdResponse) GetRequestId() uint64

func (*CommandGetLastMessageIdResponse) ProtoMessage

func (*CommandGetLastMessageIdResponse) ProtoMessage()

func (*CommandGetLastMessageIdResponse) ProtoReflect added in v0.10.0

func (*CommandGetLastMessageIdResponse) Reset

func (*CommandGetLastMessageIdResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandGetOrCreateSchema) Descriptor deprecated

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

Deprecated: Use CommandGetOrCreateSchema.ProtoReflect.Descriptor instead.

func (*CommandGetOrCreateSchema) GetRequestId

func (x *CommandGetOrCreateSchema) GetRequestId() uint64

func (*CommandGetOrCreateSchema) GetSchema

func (x *CommandGetOrCreateSchema) GetSchema() *Schema

func (*CommandGetOrCreateSchema) GetTopic

func (x *CommandGetOrCreateSchema) GetTopic() string

func (*CommandGetOrCreateSchema) ProtoMessage

func (*CommandGetOrCreateSchema) ProtoMessage()

func (*CommandGetOrCreateSchema) ProtoReflect added in v0.10.0

func (x *CommandGetOrCreateSchema) ProtoReflect() protoreflect.Message

func (*CommandGetOrCreateSchema) Reset

func (x *CommandGetOrCreateSchema) Reset()

func (*CommandGetOrCreateSchema) String

func (x *CommandGetOrCreateSchema) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandGetOrCreateSchemaResponse) Descriptor deprecated

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

Deprecated: Use CommandGetOrCreateSchemaResponse.ProtoReflect.Descriptor instead.

func (*CommandGetOrCreateSchemaResponse) GetErrorCode

func (*CommandGetOrCreateSchemaResponse) GetErrorMessage

func (x *CommandGetOrCreateSchemaResponse) GetErrorMessage() string

func (*CommandGetOrCreateSchemaResponse) GetRequestId

func (x *CommandGetOrCreateSchemaResponse) GetRequestId() uint64

func (*CommandGetOrCreateSchemaResponse) GetSchemaVersion

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

func (*CommandGetOrCreateSchemaResponse) ProtoMessage

func (*CommandGetOrCreateSchemaResponse) ProtoMessage()

func (*CommandGetOrCreateSchemaResponse) ProtoReflect added in v0.10.0

func (*CommandGetOrCreateSchemaResponse) Reset

func (*CommandGetOrCreateSchemaResponse) String

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"`
	// contains filtered or unexported fields
}

func (*CommandGetSchema) Descriptor deprecated

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

Deprecated: Use CommandGetSchema.ProtoReflect.Descriptor instead.

func (*CommandGetSchema) GetRequestId

func (x *CommandGetSchema) GetRequestId() uint64

func (*CommandGetSchema) GetSchemaVersion

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

func (*CommandGetSchema) GetTopic

func (x *CommandGetSchema) GetTopic() string

func (*CommandGetSchema) ProtoMessage

func (*CommandGetSchema) ProtoMessage()

func (*CommandGetSchema) ProtoReflect added in v0.10.0

func (x *CommandGetSchema) ProtoReflect() protoreflect.Message

func (*CommandGetSchema) Reset

func (x *CommandGetSchema) Reset()

func (*CommandGetSchema) String

func (x *CommandGetSchema) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandGetSchemaResponse) Descriptor deprecated

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

Deprecated: Use CommandGetSchemaResponse.ProtoReflect.Descriptor instead.

func (*CommandGetSchemaResponse) GetErrorCode

func (x *CommandGetSchemaResponse) GetErrorCode() ServerError

func (*CommandGetSchemaResponse) GetErrorMessage

func (x *CommandGetSchemaResponse) GetErrorMessage() string

func (*CommandGetSchemaResponse) GetRequestId

func (x *CommandGetSchemaResponse) GetRequestId() uint64

func (*CommandGetSchemaResponse) GetSchema

func (x *CommandGetSchemaResponse) GetSchema() *Schema

func (*CommandGetSchemaResponse) GetSchemaVersion

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

func (*CommandGetSchemaResponse) ProtoMessage

func (*CommandGetSchemaResponse) ProtoMessage()

func (*CommandGetSchemaResponse) ProtoReflect added in v0.10.0

func (x *CommandGetSchemaResponse) ProtoReflect() protoreflect.Message

func (*CommandGetSchemaResponse) Reset

func (x *CommandGetSchemaResponse) Reset()

func (*CommandGetSchemaResponse) String

func (x *CommandGetSchemaResponse) String() string

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"`
	TopicsPattern *string                           `protobuf:"bytes,4,opt,name=topics_pattern,json=topicsPattern" json:"topics_pattern,omitempty"`
	TopicsHash    *string                           `protobuf:"bytes,5,opt,name=topics_hash,json=topicsHash" json:"topics_hash,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandGetTopicsOfNamespace) Descriptor deprecated

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

Deprecated: Use CommandGetTopicsOfNamespace.ProtoReflect.Descriptor instead.

func (*CommandGetTopicsOfNamespace) GetMode

func (*CommandGetTopicsOfNamespace) GetNamespace

func (x *CommandGetTopicsOfNamespace) GetNamespace() string

func (*CommandGetTopicsOfNamespace) GetRequestId

func (x *CommandGetTopicsOfNamespace) GetRequestId() uint64

func (*CommandGetTopicsOfNamespace) GetTopicsHash added in v0.9.0

func (x *CommandGetTopicsOfNamespace) GetTopicsHash() string

func (*CommandGetTopicsOfNamespace) GetTopicsPattern added in v0.9.0

func (x *CommandGetTopicsOfNamespace) GetTopicsPattern() string

func (*CommandGetTopicsOfNamespace) ProtoMessage

func (*CommandGetTopicsOfNamespace) ProtoMessage()

func (*CommandGetTopicsOfNamespace) ProtoReflect added in v0.10.0

func (*CommandGetTopicsOfNamespace) Reset

func (x *CommandGetTopicsOfNamespace) Reset()

func (*CommandGetTopicsOfNamespace) String

func (x *CommandGetTopicsOfNamespace) String() string

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"`
	// true iff the topic list was filtered by the pattern supplied by the client
	Filtered *bool `protobuf:"varint,3,opt,name=filtered,def=0" json:"filtered,omitempty"`
	// hash computed from the names of matching topics
	TopicsHash *string `protobuf:"bytes,4,opt,name=topics_hash,json=topicsHash" json:"topics_hash,omitempty"`
	// if false, topics is empty and the list of matching topics has not changed
	Changed *bool `protobuf:"varint,5,opt,name=changed,def=1" json:"changed,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandGetTopicsOfNamespaceResponse) Descriptor deprecated

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

Deprecated: Use CommandGetTopicsOfNamespaceResponse.ProtoReflect.Descriptor instead.

func (*CommandGetTopicsOfNamespaceResponse) GetChanged added in v0.9.0

func (x *CommandGetTopicsOfNamespaceResponse) GetChanged() bool

func (*CommandGetTopicsOfNamespaceResponse) GetFiltered added in v0.9.0

func (x *CommandGetTopicsOfNamespaceResponse) GetFiltered() bool

func (*CommandGetTopicsOfNamespaceResponse) GetRequestId

func (x *CommandGetTopicsOfNamespaceResponse) GetRequestId() uint64

func (*CommandGetTopicsOfNamespaceResponse) GetTopics

func (*CommandGetTopicsOfNamespaceResponse) GetTopicsHash added in v0.9.0

func (x *CommandGetTopicsOfNamespaceResponse) GetTopicsHash() string

func (*CommandGetTopicsOfNamespaceResponse) ProtoMessage

func (*CommandGetTopicsOfNamespaceResponse) ProtoMessage()

func (*CommandGetTopicsOfNamespaceResponse) ProtoReflect added in v0.10.0

func (*CommandGetTopicsOfNamespaceResponse) Reset

func (*CommandGetTopicsOfNamespaceResponse) String

type CommandGetTopicsOfNamespace_Mode

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

func (CommandGetTopicsOfNamespace_Mode) Descriptor added in v0.10.0

func (CommandGetTopicsOfNamespace_Mode) Enum

func (CommandGetTopicsOfNamespace_Mode) EnumDescriptor deprecated

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

Deprecated: Use CommandGetTopicsOfNamespace_Mode.Descriptor instead.

func (CommandGetTopicsOfNamespace_Mode) Number added in v0.10.0

func (CommandGetTopicsOfNamespace_Mode) String

func (CommandGetTopicsOfNamespace_Mode) Type added in v0.10.0

func (*CommandGetTopicsOfNamespace_Mode) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	//
	AdvertisedListenerName *string `protobuf:"bytes,7,opt,name=advertised_listener_name,json=advertisedListenerName" json:"advertised_listener_name,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandLookupTopic) Descriptor deprecated

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

Deprecated: Use CommandLookupTopic.ProtoReflect.Descriptor instead.

func (*CommandLookupTopic) GetAdvertisedListenerName added in v0.5.0

func (x *CommandLookupTopic) GetAdvertisedListenerName() string

func (*CommandLookupTopic) GetAuthoritative

func (x *CommandLookupTopic) GetAuthoritative() bool

func (*CommandLookupTopic) GetOriginalAuthData

func (x *CommandLookupTopic) GetOriginalAuthData() string

func (*CommandLookupTopic) GetOriginalAuthMethod

func (x *CommandLookupTopic) GetOriginalAuthMethod() string

func (*CommandLookupTopic) GetOriginalPrincipal

func (x *CommandLookupTopic) GetOriginalPrincipal() string

func (*CommandLookupTopic) GetRequestId

func (x *CommandLookupTopic) GetRequestId() uint64

func (*CommandLookupTopic) GetTopic

func (x *CommandLookupTopic) GetTopic() string

func (*CommandLookupTopic) ProtoMessage

func (*CommandLookupTopic) ProtoMessage()

func (*CommandLookupTopic) ProtoReflect added in v0.10.0

func (x *CommandLookupTopic) ProtoReflect() protoreflect.Message

func (*CommandLookupTopic) Reset

func (x *CommandLookupTopic) Reset()

func (*CommandLookupTopic) String

func (x *CommandLookupTopic) String() string

type CommandLookupTopicResponse

type CommandLookupTopicResponse struct {
	BrokerServiceUrl    *string                                `protobuf:"bytes,1,opt,name=brokerServiceUrl" json:"brokerServiceUrl,omitempty"` // Optional in case of error
	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 */
	// contains filtered or unexported fields
}

func (*CommandLookupTopicResponse) Descriptor deprecated

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

Deprecated: Use CommandLookupTopicResponse.ProtoReflect.Descriptor instead.

func (*CommandLookupTopicResponse) GetAuthoritative

func (x *CommandLookupTopicResponse) GetAuthoritative() bool

func (*CommandLookupTopicResponse) GetBrokerServiceUrl

func (x *CommandLookupTopicResponse) GetBrokerServiceUrl() string

func (*CommandLookupTopicResponse) GetBrokerServiceUrlTls

func (x *CommandLookupTopicResponse) GetBrokerServiceUrlTls() string

func (*CommandLookupTopicResponse) GetError

func (*CommandLookupTopicResponse) GetMessage

func (x *CommandLookupTopicResponse) GetMessage() string

func (*CommandLookupTopicResponse) GetProxyThroughServiceUrl

func (x *CommandLookupTopicResponse) GetProxyThroughServiceUrl() bool

func (*CommandLookupTopicResponse) GetRequestId

func (x *CommandLookupTopicResponse) GetRequestId() uint64

func (*CommandLookupTopicResponse) GetResponse

func (*CommandLookupTopicResponse) ProtoMessage

func (*CommandLookupTopicResponse) ProtoMessage()

func (*CommandLookupTopicResponse) ProtoReflect added in v0.10.0

func (*CommandLookupTopicResponse) Reset

func (x *CommandLookupTopicResponse) Reset()

func (*CommandLookupTopicResponse) String

func (x *CommandLookupTopicResponse) String() string

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) Descriptor added in v0.10.0

func (CommandLookupTopicResponse_LookupType) Enum

func (CommandLookupTopicResponse_LookupType) EnumDescriptor deprecated

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

Deprecated: Use CommandLookupTopicResponse_LookupType.Descriptor instead.

func (CommandLookupTopicResponse_LookupType) Number added in v0.10.0

func (CommandLookupTopicResponse_LookupType) String

func (CommandLookupTopicResponse_LookupType) Type added in v0.10.0

func (*CommandLookupTopicResponse_LookupType) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	AckSet          []int64        `protobuf:"varint,4,rep,name=ack_set,json=ackSet" json:"ack_set,omitempty"`
	ConsumerEpoch   *uint64        `protobuf:"varint,5,opt,name=consumer_epoch,json=consumerEpoch" json:"consumer_epoch,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandMessage) Descriptor deprecated

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

Deprecated: Use CommandMessage.ProtoReflect.Descriptor instead.

func (*CommandMessage) GetAckSet added in v0.6.0

func (x *CommandMessage) GetAckSet() []int64

func (*CommandMessage) GetConsumerEpoch added in v0.9.0

func (x *CommandMessage) GetConsumerEpoch() uint64

func (*CommandMessage) GetConsumerId

func (x *CommandMessage) GetConsumerId() uint64

func (*CommandMessage) GetMessageId

func (x *CommandMessage) GetMessageId() *MessageIdData

func (*CommandMessage) GetRedeliveryCount

func (x *CommandMessage) GetRedeliveryCount() uint32

func (*CommandMessage) ProtoMessage

func (*CommandMessage) ProtoMessage()

func (*CommandMessage) ProtoReflect added in v0.10.0

func (x *CommandMessage) ProtoReflect() protoreflect.Message

func (*CommandMessage) Reset

func (x *CommandMessage) Reset()

func (*CommandMessage) String

func (x *CommandMessage) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandNewTxn) Descriptor deprecated

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

Deprecated: Use CommandNewTxn.ProtoReflect.Descriptor instead.

func (*CommandNewTxn) GetRequestId

func (x *CommandNewTxn) GetRequestId() uint64

func (*CommandNewTxn) GetTcId

func (x *CommandNewTxn) GetTcId() uint64

func (*CommandNewTxn) GetTxnTtlSeconds

func (x *CommandNewTxn) GetTxnTtlSeconds() uint64

func (*CommandNewTxn) ProtoMessage

func (*CommandNewTxn) ProtoMessage()

func (*CommandNewTxn) ProtoReflect added in v0.10.0

func (x *CommandNewTxn) ProtoReflect() protoreflect.Message

func (*CommandNewTxn) Reset

func (x *CommandNewTxn) Reset()

func (*CommandNewTxn) String

func (x *CommandNewTxn) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandNewTxnResponse) Descriptor deprecated

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

Deprecated: Use CommandNewTxnResponse.ProtoReflect.Descriptor instead.

func (*CommandNewTxnResponse) GetError

func (x *CommandNewTxnResponse) GetError() ServerError

func (*CommandNewTxnResponse) GetMessage

func (x *CommandNewTxnResponse) GetMessage() string

func (*CommandNewTxnResponse) GetRequestId

func (x *CommandNewTxnResponse) GetRequestId() uint64

func (*CommandNewTxnResponse) GetTxnidLeastBits

func (x *CommandNewTxnResponse) GetTxnidLeastBits() uint64

func (*CommandNewTxnResponse) GetTxnidMostBits

func (x *CommandNewTxnResponse) GetTxnidMostBits() uint64

func (*CommandNewTxnResponse) ProtoMessage

func (*CommandNewTxnResponse) ProtoMessage()

func (*CommandNewTxnResponse) ProtoReflect added in v0.10.0

func (x *CommandNewTxnResponse) ProtoReflect() protoreflect.Message

func (*CommandNewTxnResponse) Reset

func (x *CommandNewTxnResponse) Reset()

func (*CommandNewTxnResponse) String

func (x *CommandNewTxnResponse) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandPartitionedTopicMetadata) Descriptor deprecated

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

Deprecated: Use CommandPartitionedTopicMetadata.ProtoReflect.Descriptor instead.

func (*CommandPartitionedTopicMetadata) GetOriginalAuthData

func (x *CommandPartitionedTopicMetadata) GetOriginalAuthData() string

func (*CommandPartitionedTopicMetadata) GetOriginalAuthMethod

func (x *CommandPartitionedTopicMetadata) GetOriginalAuthMethod() string

func (*CommandPartitionedTopicMetadata) GetOriginalPrincipal

func (x *CommandPartitionedTopicMetadata) GetOriginalPrincipal() string

func (*CommandPartitionedTopicMetadata) GetRequestId

func (x *CommandPartitionedTopicMetadata) GetRequestId() uint64

func (*CommandPartitionedTopicMetadata) GetTopic

func (*CommandPartitionedTopicMetadata) ProtoMessage

func (*CommandPartitionedTopicMetadata) ProtoMessage()

func (*CommandPartitionedTopicMetadata) ProtoReflect added in v0.10.0

func (*CommandPartitionedTopicMetadata) Reset

func (*CommandPartitionedTopicMetadata) String

type CommandPartitionedTopicMetadataResponse

type CommandPartitionedTopicMetadataResponse struct {
	Partitions *uint32                                             `protobuf:"varint,1,opt,name=partitions" json:"partitions,omitempty"` // Optional in case of error
	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"`
	// contains filtered or unexported fields
}

func (*CommandPartitionedTopicMetadataResponse) Descriptor deprecated

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

Deprecated: Use CommandPartitionedTopicMetadataResponse.ProtoReflect.Descriptor instead.

func (*CommandPartitionedTopicMetadataResponse) GetError

func (*CommandPartitionedTopicMetadataResponse) GetMessage

func (*CommandPartitionedTopicMetadataResponse) GetPartitions

func (*CommandPartitionedTopicMetadataResponse) GetRequestId

func (*CommandPartitionedTopicMetadataResponse) GetResponse

func (*CommandPartitionedTopicMetadataResponse) ProtoMessage

func (*CommandPartitionedTopicMetadataResponse) ProtoReflect added in v0.10.0

func (*CommandPartitionedTopicMetadataResponse) Reset

func (*CommandPartitionedTopicMetadataResponse) String

type CommandPartitionedTopicMetadataResponse_LookupType

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

func (CommandPartitionedTopicMetadataResponse_LookupType) Descriptor added in v0.10.0

func (CommandPartitionedTopicMetadataResponse_LookupType) Enum

func (CommandPartitionedTopicMetadataResponse_LookupType) EnumDescriptor deprecated

Deprecated: Use CommandPartitionedTopicMetadataResponse_LookupType.Descriptor instead.

func (CommandPartitionedTopicMetadataResponse_LookupType) Number added in v0.10.0

func (CommandPartitionedTopicMetadataResponse_LookupType) String

func (CommandPartitionedTopicMetadataResponse_LookupType) Type added in v0.10.0

func (*CommandPartitionedTopicMetadataResponse_LookupType) UnmarshalJSON deprecated

Deprecated: Do not use.

type CommandPing

type CommandPing struct {
	// contains filtered or unexported fields
}

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 deprecated

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

Deprecated: Use CommandPing.ProtoReflect.Descriptor instead.

func (*CommandPing) ProtoMessage

func (*CommandPing) ProtoMessage()

func (*CommandPing) ProtoReflect added in v0.10.0

func (x *CommandPing) ProtoReflect() protoreflect.Message

func (*CommandPing) Reset

func (x *CommandPing) Reset()

func (*CommandPing) String

func (x *CommandPing) String() string

type CommandPong

type CommandPong struct {
	// contains filtered or unexported fields
}

func (*CommandPong) Descriptor deprecated

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

Deprecated: Use CommandPong.ProtoReflect.Descriptor instead.

func (*CommandPong) ProtoMessage

func (*CommandPong) ProtoMessage()

func (*CommandPong) ProtoReflect added in v0.10.0

func (x *CommandPong) ProtoReflect() protoreflect.Message

func (*CommandPong) Reset

func (x *CommandPong) Reset()

func (*CommandPong) String

func (x *CommandPong) String() string

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 */
	// Require that this producers will be the only producer allowed on the topic
	ProducerAccessMode *ProducerAccessMode `` /* 155-byte string literal not displayed */
	// Topic epoch is used to fence off producers that reconnects after a new
	// exclusive producer has already taken over. This id is assigned by the
	// broker on the CommandProducerSuccess. The first time, the client will
	// leave it empty and then it will always carry the same epoch number on
	// the subsequent reconnections.
	TopicEpoch *uint64 `protobuf:"varint,11,opt,name=topic_epoch,json=topicEpoch" json:"topic_epoch,omitempty"`
	TxnEnabled *bool   `protobuf:"varint,12,opt,name=txn_enabled,json=txnEnabled,def=0" json:"txn_enabled,omitempty"`
	// Name of the initial subscription of the topic.
	// If this field is not set, the initial subscription will not be created.
	// If this field is set but the broker's `allowAutoSubscriptionCreation`
	// is disabled, the producer will fail to be created.
	InitialSubscriptionName *string `` /* 126-byte string literal not displayed */
	// contains filtered or unexported fields
}

/ 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 deprecated

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

Deprecated: Use CommandProducer.ProtoReflect.Descriptor instead.

func (*CommandProducer) GetEncrypted

func (x *CommandProducer) GetEncrypted() bool

func (*CommandProducer) GetEpoch

func (x *CommandProducer) GetEpoch() uint64

func (*CommandProducer) GetInitialSubscriptionName added in v0.9.0

func (x *CommandProducer) GetInitialSubscriptionName() string

func (*CommandProducer) GetMetadata

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

func (*CommandProducer) GetProducerAccessMode added in v0.6.0

func (x *CommandProducer) GetProducerAccessMode() ProducerAccessMode

func (*CommandProducer) GetProducerId

func (x *CommandProducer) GetProducerId() uint64

func (*CommandProducer) GetProducerName

func (x *CommandProducer) GetProducerName() string

func (*CommandProducer) GetRequestId

func (x *CommandProducer) GetRequestId() uint64

func (*CommandProducer) GetSchema

func (x *CommandProducer) GetSchema() *Schema

func (*CommandProducer) GetTopic

func (x *CommandProducer) GetTopic() string

func (*CommandProducer) GetTopicEpoch added in v0.6.0

func (x *CommandProducer) GetTopicEpoch() uint64

func (*CommandProducer) GetTxnEnabled added in v0.8.0

func (x *CommandProducer) GetTxnEnabled() bool

func (*CommandProducer) GetUserProvidedProducerName

func (x *CommandProducer) GetUserProvidedProducerName() bool

func (*CommandProducer) ProtoMessage

func (*CommandProducer) ProtoMessage()

func (*CommandProducer) ProtoReflect added in v0.10.0

func (x *CommandProducer) ProtoReflect() protoreflect.Message

func (*CommandProducer) Reset

func (x *CommandProducer) Reset()

func (*CommandProducer) String

func (x *CommandProducer) String() string

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"`
	// The topic epoch assigned by the broker. This field will only be set if we
	// were requiring exclusive access when creating the producer.
	TopicEpoch *uint64 `protobuf:"varint,5,opt,name=topic_epoch,json=topicEpoch" json:"topic_epoch,omitempty"`
	// If producer is not "ready", the client will avoid to timeout the request
	// for creating the producer. Instead it will wait indefinitely until it gets
	// a subsequent  `CommandProducerSuccess` with `producer_ready==true`.
	ProducerReady *bool `protobuf:"varint,6,opt,name=producer_ready,json=producerReady,def=1" json:"producer_ready,omitempty"`
	// contains filtered or unexported fields
}

/ Response from CommandProducer

func (*CommandProducerSuccess) Descriptor deprecated

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

Deprecated: Use CommandProducerSuccess.ProtoReflect.Descriptor instead.

func (*CommandProducerSuccess) GetLastSequenceId

func (x *CommandProducerSuccess) GetLastSequenceId() int64

func (*CommandProducerSuccess) GetProducerName

func (x *CommandProducerSuccess) GetProducerName() string

func (*CommandProducerSuccess) GetProducerReady added in v0.6.0

func (x *CommandProducerSuccess) GetProducerReady() bool

func (*CommandProducerSuccess) GetRequestId

func (x *CommandProducerSuccess) GetRequestId() uint64

func (*CommandProducerSuccess) GetSchemaVersion

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

func (*CommandProducerSuccess) GetTopicEpoch added in v0.6.0

func (x *CommandProducerSuccess) GetTopicEpoch() uint64

func (*CommandProducerSuccess) ProtoMessage

func (*CommandProducerSuccess) ProtoMessage()

func (*CommandProducerSuccess) ProtoReflect added in v0.10.0

func (x *CommandProducerSuccess) ProtoReflect() protoreflect.Message

func (*CommandProducerSuccess) Reset

func (x *CommandProducerSuccess) Reset()

func (*CommandProducerSuccess) String

func (x *CommandProducerSuccess) String() string

type CommandReachedEndOfTopic

type CommandReachedEndOfTopic struct {
	ConsumerId *uint64 `protobuf:"varint,1,req,name=consumer_id,json=consumerId" json:"consumer_id,omitempty"`
	// contains filtered or unexported fields
}

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 deprecated

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

Deprecated: Use CommandReachedEndOfTopic.ProtoReflect.Descriptor instead.

func (*CommandReachedEndOfTopic) GetConsumerId

func (x *CommandReachedEndOfTopic) GetConsumerId() uint64

func (*CommandReachedEndOfTopic) ProtoMessage

func (*CommandReachedEndOfTopic) ProtoMessage()

func (*CommandReachedEndOfTopic) ProtoReflect added in v0.10.0

func (x *CommandReachedEndOfTopic) ProtoReflect() protoreflect.Message

func (*CommandReachedEndOfTopic) Reset

func (x *CommandReachedEndOfTopic) Reset()

func (*CommandReachedEndOfTopic) String

func (x *CommandReachedEndOfTopic) String() string

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"`
	ConsumerEpoch *uint64          `protobuf:"varint,3,opt,name=consumer_epoch,json=consumerEpoch" json:"consumer_epoch,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandRedeliverUnacknowledgedMessages) Descriptor deprecated

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

Deprecated: Use CommandRedeliverUnacknowledgedMessages.ProtoReflect.Descriptor instead.

func (*CommandRedeliverUnacknowledgedMessages) GetConsumerEpoch added in v0.9.0

func (x *CommandRedeliverUnacknowledgedMessages) GetConsumerEpoch() uint64

func (*CommandRedeliverUnacknowledgedMessages) GetConsumerId

func (*CommandRedeliverUnacknowledgedMessages) GetMessageIds

func (*CommandRedeliverUnacknowledgedMessages) ProtoMessage

func (*CommandRedeliverUnacknowledgedMessages) ProtoReflect added in v0.10.0

func (*CommandRedeliverUnacknowledgedMessages) Reset

func (*CommandRedeliverUnacknowledgedMessages) String

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"`
	// contains filtered or unexported fields
}

Reset an existing consumer to a particular message id

func (*CommandSeek) Descriptor deprecated

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

Deprecated: Use CommandSeek.ProtoReflect.Descriptor instead.

func (*CommandSeek) GetConsumerId

func (x *CommandSeek) GetConsumerId() uint64

func (*CommandSeek) GetMessageId

func (x *CommandSeek) GetMessageId() *MessageIdData

func (*CommandSeek) GetMessagePublishTime

func (x *CommandSeek) GetMessagePublishTime() uint64

func (*CommandSeek) GetRequestId

func (x *CommandSeek) GetRequestId() uint64

func (*CommandSeek) ProtoMessage

func (*CommandSeek) ProtoMessage()

func (*CommandSeek) ProtoReflect added in v0.10.0

func (x *CommandSeek) ProtoReflect() protoreflect.Message

func (*CommandSeek) Reset

func (x *CommandSeek) Reset()

func (*CommandSeek) String

func (x *CommandSeek) String() string

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"`
	IsChunk           *bool   `protobuf:"varint,7,opt,name=is_chunk,json=isChunk,def=0" json:"is_chunk,omitempty"`
	// Specify if the message being published is a Pulsar marker or not
	Marker *bool `protobuf:"varint,8,opt,name=marker,def=0" json:"marker,omitempty"`
	// Message id of this message, currently is used in replicator for shadow topic.
	MessageId *MessageIdData `protobuf:"bytes,9,opt,name=message_id,json=messageId" json:"message_id,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandSend) Descriptor deprecated

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

Deprecated: Use CommandSend.ProtoReflect.Descriptor instead.

func (*CommandSend) GetHighestSequenceId

func (x *CommandSend) GetHighestSequenceId() uint64

func (*CommandSend) GetIsChunk added in v0.6.0

func (x *CommandSend) GetIsChunk() bool

func (*CommandSend) GetMarker added in v0.8.0

func (x *CommandSend) GetMarker() bool

func (*CommandSend) GetMessageId added in v0.9.0

func (x *CommandSend) GetMessageId() *MessageIdData

func (*CommandSend) GetNumMessages

func (x *CommandSend) GetNumMessages() int32

func (*CommandSend) GetProducerId

func (x *CommandSend) GetProducerId() uint64

func (*CommandSend) GetSequenceId

func (x *CommandSend) GetSequenceId() uint64

func (*CommandSend) GetTxnidLeastBits

func (x *CommandSend) GetTxnidLeastBits() uint64

func (*CommandSend) GetTxnidMostBits

func (x *CommandSend) GetTxnidMostBits() uint64

func (*CommandSend) ProtoMessage

func (*CommandSend) ProtoMessage()

func (*CommandSend) ProtoReflect added in v0.10.0

func (x *CommandSend) ProtoReflect() protoreflect.Message

func (*CommandSend) Reset

func (x *CommandSend) Reset()

func (*CommandSend) String

func (x *CommandSend) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandSendError) Descriptor deprecated

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

Deprecated: Use CommandSendError.ProtoReflect.Descriptor instead.

func (*CommandSendError) GetError

func (x *CommandSendError) GetError() ServerError

func (*CommandSendError) GetMessage

func (x *CommandSendError) GetMessage() string

func (*CommandSendError) GetProducerId

func (x *CommandSendError) GetProducerId() uint64

func (*CommandSendError) GetSequenceId

func (x *CommandSendError) GetSequenceId() uint64

func (*CommandSendError) ProtoMessage

func (*CommandSendError) ProtoMessage()

func (*CommandSendError) ProtoReflect added in v0.10.0

func (x *CommandSendError) ProtoReflect() protoreflect.Message

func (*CommandSendError) Reset

func (x *CommandSendError) Reset()

func (*CommandSendError) String

func (x *CommandSendError) String() string

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"`
	// contains filtered or unexported fields
}

func (*CommandSendReceipt) Descriptor deprecated

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

Deprecated: Use CommandSendReceipt.ProtoReflect.Descriptor instead.

func (*CommandSendReceipt) GetHighestSequenceId

func (x *CommandSendReceipt) GetHighestSequenceId() uint64

func (*CommandSendReceipt) GetMessageId

func (x *CommandSendReceipt) GetMessageId() *MessageIdData

func (*CommandSendReceipt) GetProducerId

func (x *CommandSendReceipt) GetProducerId() uint64

func (*CommandSendReceipt) GetSequenceId

func (x *CommandSendReceipt) GetSequenceId() uint64

func (*CommandSendReceipt) ProtoMessage

func (*CommandSendReceipt) ProtoMessage()

func (*CommandSendReceipt) ProtoReflect added in v0.10.0

func (x *CommandSendReceipt) ProtoReflect() protoreflect.Message

func (*CommandSendReceipt) Reset

func (x *CommandSendReceipt) Reset()

func (*CommandSendReceipt) String

func (x *CommandSendReceipt) String() string

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"`
	SubscriptionProperties          []*KeyValue    `protobuf:"bytes,18,rep,name=subscription_properties,json=subscriptionProperties" json:"subscription_properties,omitempty"`
	// The consumer epoch, when exclusive and failover consumer redeliver unack message will increase the epoch
	ConsumerEpoch *uint64 `protobuf:"varint,19,opt,name=consumer_epoch,json=consumerEpoch" json:"consumer_epoch,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandSubscribe) Descriptor deprecated

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

Deprecated: Use CommandSubscribe.ProtoReflect.Descriptor instead.

func (*CommandSubscribe) GetConsumerEpoch added in v0.9.0

func (x *CommandSubscribe) GetConsumerEpoch() uint64

func (*CommandSubscribe) GetConsumerId

func (x *CommandSubscribe) GetConsumerId() uint64

func (*CommandSubscribe) GetConsumerName

func (x *CommandSubscribe) GetConsumerName() string

func (*CommandSubscribe) GetDurable

func (x *CommandSubscribe) GetDurable() bool

func (*CommandSubscribe) GetForceTopicCreation

func (x *CommandSubscribe) GetForceTopicCreation() bool

func (*CommandSubscribe) GetInitialPosition

func (x *CommandSubscribe) GetInitialPosition() CommandSubscribe_InitialPosition

func (*CommandSubscribe) GetKeySharedMeta

func (x *CommandSubscribe) GetKeySharedMeta() *KeySharedMeta

func (*CommandSubscribe) GetMetadata

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

func (*CommandSubscribe) GetPriorityLevel

func (x *CommandSubscribe) GetPriorityLevel() int32

func (*CommandSubscribe) GetReadCompacted

func (x *CommandSubscribe) GetReadCompacted() bool

func (*CommandSubscribe) GetReplicateSubscriptionState

func (x *CommandSubscribe) GetReplicateSubscriptionState() bool

func (*CommandSubscribe) GetRequestId

func (x *CommandSubscribe) GetRequestId() uint64

func (*CommandSubscribe) GetSchema

func (x *CommandSubscribe) GetSchema() *Schema

func (*CommandSubscribe) GetStartMessageId

func (x *CommandSubscribe) GetStartMessageId() *MessageIdData

func (*CommandSubscribe) GetStartMessageRollbackDurationSec

func (x *CommandSubscribe) GetStartMessageRollbackDurationSec() uint64

func (*CommandSubscribe) GetSubType

func (*CommandSubscribe) GetSubscription

func (x *CommandSubscribe) GetSubscription() string

func (*CommandSubscribe) GetSubscriptionProperties added in v0.8.0

func (x *CommandSubscribe) GetSubscriptionProperties() []*KeyValue

func (*CommandSubscribe) GetTopic

func (x *CommandSubscribe) GetTopic() string

func (*CommandSubscribe) ProtoMessage

func (*CommandSubscribe) ProtoMessage()

func (*CommandSubscribe) ProtoReflect added in v0.10.0

func (x *CommandSubscribe) ProtoReflect() protoreflect.Message

func (*CommandSubscribe) Reset

func (x *CommandSubscribe) Reset()

func (*CommandSubscribe) String

func (x *CommandSubscribe) String() string

type CommandSubscribe_InitialPosition

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

func (CommandSubscribe_InitialPosition) Descriptor added in v0.10.0

func (CommandSubscribe_InitialPosition) Enum

func (CommandSubscribe_InitialPosition) EnumDescriptor deprecated

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

Deprecated: Use CommandSubscribe_InitialPosition.Descriptor instead.

func (CommandSubscribe_InitialPosition) Number added in v0.10.0

func (CommandSubscribe_InitialPosition) String

func (CommandSubscribe_InitialPosition) Type added in v0.10.0

func (*CommandSubscribe_InitialPosition) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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) Descriptor added in v0.10.0

func (CommandSubscribe_SubType) Enum

func (CommandSubscribe_SubType) EnumDescriptor deprecated

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

Deprecated: Use CommandSubscribe_SubType.Descriptor instead.

func (CommandSubscribe_SubType) Number added in v0.10.0

func (CommandSubscribe_SubType) String

func (x CommandSubscribe_SubType) String() string

func (CommandSubscribe_SubType) Type added in v0.10.0

func (*CommandSubscribe_SubType) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// contains filtered or unexported fields
}

func (*CommandSuccess) Descriptor deprecated

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

Deprecated: Use CommandSuccess.ProtoReflect.Descriptor instead.

func (*CommandSuccess) GetRequestId

func (x *CommandSuccess) GetRequestId() uint64

func (*CommandSuccess) GetSchema

func (x *CommandSuccess) GetSchema() *Schema

func (*CommandSuccess) ProtoMessage

func (*CommandSuccess) ProtoMessage()

func (*CommandSuccess) ProtoReflect added in v0.10.0

func (x *CommandSuccess) ProtoReflect() protoreflect.Message

func (*CommandSuccess) Reset

func (x *CommandSuccess) Reset()

func (*CommandSuccess) String

func (x *CommandSuccess) String() string

type CommandTcClientConnectRequest added in v0.8.0

type CommandTcClientConnectRequest struct {
	RequestId *uint64 `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	TcId      *uint64 `protobuf:"varint,2,req,name=tc_id,json=tcId,def=0" json:"tc_id,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandTcClientConnectRequest) Descriptor deprecated added in v0.8.0

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

Deprecated: Use CommandTcClientConnectRequest.ProtoReflect.Descriptor instead.

func (*CommandTcClientConnectRequest) GetRequestId added in v0.8.0

func (x *CommandTcClientConnectRequest) GetRequestId() uint64

func (*CommandTcClientConnectRequest) GetTcId added in v0.8.0

func (*CommandTcClientConnectRequest) ProtoMessage added in v0.8.0

func (*CommandTcClientConnectRequest) ProtoMessage()

func (*CommandTcClientConnectRequest) ProtoReflect added in v0.10.0

func (*CommandTcClientConnectRequest) Reset added in v0.8.0

func (x *CommandTcClientConnectRequest) Reset()

func (*CommandTcClientConnectRequest) String added in v0.8.0

type CommandTcClientConnectResponse added in v0.8.0

type CommandTcClientConnectResponse struct {
	RequestId *uint64      `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	Error     *ServerError `protobuf:"varint,2,opt,name=error,enum=pulsar.proto.ServerError" json:"error,omitempty"`
	Message   *string      `protobuf:"bytes,3,opt,name=message" json:"message,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandTcClientConnectResponse) Descriptor deprecated added in v0.8.0

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

Deprecated: Use CommandTcClientConnectResponse.ProtoReflect.Descriptor instead.

func (*CommandTcClientConnectResponse) GetError added in v0.8.0

func (*CommandTcClientConnectResponse) GetMessage added in v0.8.0

func (x *CommandTcClientConnectResponse) GetMessage() string

func (*CommandTcClientConnectResponse) GetRequestId added in v0.8.0

func (x *CommandTcClientConnectResponse) GetRequestId() uint64

func (*CommandTcClientConnectResponse) ProtoMessage added in v0.8.0

func (*CommandTcClientConnectResponse) ProtoMessage()

func (*CommandTcClientConnectResponse) ProtoReflect added in v0.10.0

func (*CommandTcClientConnectResponse) Reset added in v0.8.0

func (x *CommandTcClientConnectResponse) Reset()

func (*CommandTcClientConnectResponse) String added in v0.8.0

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"`
	// contains filtered or unexported fields
}

func (*CommandUnsubscribe) Descriptor deprecated

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

Deprecated: Use CommandUnsubscribe.ProtoReflect.Descriptor instead.

func (*CommandUnsubscribe) GetConsumerId

func (x *CommandUnsubscribe) GetConsumerId() uint64

func (*CommandUnsubscribe) GetRequestId

func (x *CommandUnsubscribe) GetRequestId() uint64

func (*CommandUnsubscribe) ProtoMessage

func (*CommandUnsubscribe) ProtoMessage()

func (*CommandUnsubscribe) ProtoReflect added in v0.10.0

func (x *CommandUnsubscribe) ProtoReflect() protoreflect.Message

func (*CommandUnsubscribe) Reset

func (x *CommandUnsubscribe) Reset()

func (*CommandUnsubscribe) String

func (x *CommandUnsubscribe) String() string

type CommandWatchTopicList added in v0.9.0

type CommandWatchTopicList struct {
	RequestId     *uint64 `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	WatcherId     *uint64 `protobuf:"varint,2,req,name=watcher_id,json=watcherId" json:"watcher_id,omitempty"`
	Namespace     *string `protobuf:"bytes,3,req,name=namespace" json:"namespace,omitempty"`
	TopicsPattern *string `protobuf:"bytes,4,req,name=topics_pattern,json=topicsPattern" json:"topics_pattern,omitempty"`
	// Only present when the client reconnects:
	TopicsHash *string `protobuf:"bytes,5,opt,name=topics_hash,json=topicsHash" json:"topics_hash,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandWatchTopicList) Descriptor deprecated added in v0.9.0

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

Deprecated: Use CommandWatchTopicList.ProtoReflect.Descriptor instead.

func (*CommandWatchTopicList) GetNamespace added in v0.9.0

func (x *CommandWatchTopicList) GetNamespace() string

func (*CommandWatchTopicList) GetRequestId added in v0.9.0

func (x *CommandWatchTopicList) GetRequestId() uint64

func (*CommandWatchTopicList) GetTopicsHash added in v0.9.0

func (x *CommandWatchTopicList) GetTopicsHash() string

func (*CommandWatchTopicList) GetTopicsPattern added in v0.9.0

func (x *CommandWatchTopicList) GetTopicsPattern() string

func (*CommandWatchTopicList) GetWatcherId added in v0.9.0

func (x *CommandWatchTopicList) GetWatcherId() uint64

func (*CommandWatchTopicList) ProtoMessage added in v0.9.0

func (*CommandWatchTopicList) ProtoMessage()

func (*CommandWatchTopicList) ProtoReflect added in v0.10.0

func (x *CommandWatchTopicList) ProtoReflect() protoreflect.Message

func (*CommandWatchTopicList) Reset added in v0.9.0

func (x *CommandWatchTopicList) Reset()

func (*CommandWatchTopicList) String added in v0.9.0

func (x *CommandWatchTopicList) String() string

type CommandWatchTopicListClose added in v0.9.0

type CommandWatchTopicListClose struct {
	RequestId *uint64 `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	WatcherId *uint64 `protobuf:"varint,2,req,name=watcher_id,json=watcherId" json:"watcher_id,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandWatchTopicListClose) Descriptor deprecated added in v0.9.0

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

Deprecated: Use CommandWatchTopicListClose.ProtoReflect.Descriptor instead.

func (*CommandWatchTopicListClose) GetRequestId added in v0.9.0

func (x *CommandWatchTopicListClose) GetRequestId() uint64

func (*CommandWatchTopicListClose) GetWatcherId added in v0.9.0

func (x *CommandWatchTopicListClose) GetWatcherId() uint64

func (*CommandWatchTopicListClose) ProtoMessage added in v0.9.0

func (*CommandWatchTopicListClose) ProtoMessage()

func (*CommandWatchTopicListClose) ProtoReflect added in v0.10.0

func (*CommandWatchTopicListClose) Reset added in v0.9.0

func (x *CommandWatchTopicListClose) Reset()

func (*CommandWatchTopicListClose) String added in v0.9.0

func (x *CommandWatchTopicListClose) String() string

type CommandWatchTopicListSuccess added in v0.9.0

type CommandWatchTopicListSuccess struct {
	RequestId  *uint64  `protobuf:"varint,1,req,name=request_id,json=requestId" json:"request_id,omitempty"`
	WatcherId  *uint64  `protobuf:"varint,2,req,name=watcher_id,json=watcherId" json:"watcher_id,omitempty"`
	Topic      []string `protobuf:"bytes,3,rep,name=topic" json:"topic,omitempty"`
	TopicsHash *string  `protobuf:"bytes,4,req,name=topics_hash,json=topicsHash" json:"topics_hash,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandWatchTopicListSuccess) Descriptor deprecated added in v0.9.0

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

Deprecated: Use CommandWatchTopicListSuccess.ProtoReflect.Descriptor instead.

func (*CommandWatchTopicListSuccess) GetRequestId added in v0.9.0

func (x *CommandWatchTopicListSuccess) GetRequestId() uint64

func (*CommandWatchTopicListSuccess) GetTopic added in v0.9.0

func (x *CommandWatchTopicListSuccess) GetTopic() []string

func (*CommandWatchTopicListSuccess) GetTopicsHash added in v0.9.0

func (x *CommandWatchTopicListSuccess) GetTopicsHash() string

func (*CommandWatchTopicListSuccess) GetWatcherId added in v0.9.0

func (x *CommandWatchTopicListSuccess) GetWatcherId() uint64

func (*CommandWatchTopicListSuccess) ProtoMessage added in v0.9.0

func (*CommandWatchTopicListSuccess) ProtoMessage()

func (*CommandWatchTopicListSuccess) ProtoReflect added in v0.10.0

func (*CommandWatchTopicListSuccess) Reset added in v0.9.0

func (x *CommandWatchTopicListSuccess) Reset()

func (*CommandWatchTopicListSuccess) String added in v0.9.0

type CommandWatchTopicUpdate added in v0.9.0

type CommandWatchTopicUpdate struct {
	WatcherId     *uint64  `protobuf:"varint,1,req,name=watcher_id,json=watcherId" json:"watcher_id,omitempty"`
	NewTopics     []string `protobuf:"bytes,2,rep,name=new_topics,json=newTopics" json:"new_topics,omitempty"`
	DeletedTopics []string `protobuf:"bytes,3,rep,name=deleted_topics,json=deletedTopics" json:"deleted_topics,omitempty"`
	TopicsHash    *string  `protobuf:"bytes,4,req,name=topics_hash,json=topicsHash" json:"topics_hash,omitempty"`
	// contains filtered or unexported fields
}

func (*CommandWatchTopicUpdate) Descriptor deprecated added in v0.9.0

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

Deprecated: Use CommandWatchTopicUpdate.ProtoReflect.Descriptor instead.

func (*CommandWatchTopicUpdate) GetDeletedTopics added in v0.9.0

func (x *CommandWatchTopicUpdate) GetDeletedTopics() []string

func (*CommandWatchTopicUpdate) GetNewTopics added in v0.9.0

func (x *CommandWatchTopicUpdate) GetNewTopics() []string

func (*CommandWatchTopicUpdate) GetTopicsHash added in v0.9.0

func (x *CommandWatchTopicUpdate) GetTopicsHash() string

func (*CommandWatchTopicUpdate) GetWatcherId added in v0.9.0

func (x *CommandWatchTopicUpdate) GetWatcherId() uint64

func (*CommandWatchTopicUpdate) ProtoMessage added in v0.9.0

func (*CommandWatchTopicUpdate) ProtoMessage()

func (*CommandWatchTopicUpdate) ProtoReflect added in v0.10.0

func (x *CommandWatchTopicUpdate) ProtoReflect() protoreflect.Message

func (*CommandWatchTopicUpdate) Reset added in v0.9.0

func (x *CommandWatchTopicUpdate) Reset()

func (*CommandWatchTopicUpdate) String added in v0.9.0

func (x *CommandWatchTopicUpdate) String() string

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
)

func (CompressionType) Descriptor added in v0.10.0

func (CompressionType) Enum

func (x CompressionType) Enum() *CompressionType

func (CompressionType) EnumDescriptor deprecated

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

Deprecated: Use CompressionType.Descriptor instead.

func (CompressionType) Number added in v0.10.0

func (CompressionType) String

func (x CompressionType) String() string

func (CompressionType) Type added in v0.10.0

func (*CompressionType) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// contains filtered or unexported fields
}

func (*EncryptionKeys) Descriptor deprecated

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

Deprecated: Use EncryptionKeys.ProtoReflect.Descriptor instead.

func (*EncryptionKeys) GetKey

func (x *EncryptionKeys) GetKey() string

func (*EncryptionKeys) GetMetadata

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

func (*EncryptionKeys) GetValue

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

func (*EncryptionKeys) ProtoMessage

func (*EncryptionKeys) ProtoMessage()

func (*EncryptionKeys) ProtoReflect added in v0.10.0

func (x *EncryptionKeys) ProtoReflect() protoreflect.Message

func (*EncryptionKeys) Reset

func (x *EncryptionKeys) Reset()

func (*EncryptionKeys) String

func (x *EncryptionKeys) String() string

type FeatureFlags

type FeatureFlags struct {
	SupportsAuthRefresh         *bool `protobuf:"varint,1,opt,name=supports_auth_refresh,json=supportsAuthRefresh,def=0" json:"supports_auth_refresh,omitempty"`
	SupportsBrokerEntryMetadata *bool `` /* 146-byte string literal not displayed */
	SupportsPartialProducer     *bool `` /* 132-byte string literal not displayed */
	SupportsTopicWatchers       *bool `` /* 126-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*FeatureFlags) Descriptor deprecated

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

Deprecated: Use FeatureFlags.ProtoReflect.Descriptor instead.

func (*FeatureFlags) GetSupportsAuthRefresh

func (x *FeatureFlags) GetSupportsAuthRefresh() bool

func (*FeatureFlags) GetSupportsBrokerEntryMetadata added in v0.6.0

func (x *FeatureFlags) GetSupportsBrokerEntryMetadata() bool

func (*FeatureFlags) GetSupportsPartialProducer added in v0.9.0

func (x *FeatureFlags) GetSupportsPartialProducer() bool

func (*FeatureFlags) GetSupportsTopicWatchers added in v0.9.0

func (x *FeatureFlags) GetSupportsTopicWatchers() bool

func (*FeatureFlags) ProtoMessage

func (*FeatureFlags) ProtoMessage()

func (*FeatureFlags) ProtoReflect added in v0.10.0

func (x *FeatureFlags) ProtoReflect() protoreflect.Message

func (*FeatureFlags) Reset

func (x *FeatureFlags) Reset()

func (*FeatureFlags) String

func (x *FeatureFlags) String() string

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"`
	// contains filtered or unexported fields
}

func (*IntRange) Descriptor deprecated

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

Deprecated: Use IntRange.ProtoReflect.Descriptor instead.

func (*IntRange) GetEnd

func (x *IntRange) GetEnd() int32

func (*IntRange) GetStart

func (x *IntRange) GetStart() int32

func (*IntRange) ProtoMessage

func (*IntRange) ProtoMessage()

func (*IntRange) ProtoReflect added in v0.10.0

func (x *IntRange) ProtoReflect() protoreflect.Message

func (*IntRange) Reset

func (x *IntRange) Reset()

func (*IntRange) String

func (x *IntRange) String() string

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"`
	// contains filtered or unexported fields
}

func (*KeyLongValue) Descriptor deprecated

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

Deprecated: Use KeyLongValue.ProtoReflect.Descriptor instead.

func (*KeyLongValue) GetKey

func (x *KeyLongValue) GetKey() string

func (*KeyLongValue) GetValue

func (x *KeyLongValue) GetValue() uint64

func (*KeyLongValue) ProtoMessage

func (*KeyLongValue) ProtoMessage()

func (*KeyLongValue) ProtoReflect added in v0.10.0

func (x *KeyLongValue) ProtoReflect() protoreflect.Message

func (*KeyLongValue) Reset

func (x *KeyLongValue) Reset()

func (*KeyLongValue) String

func (x *KeyLongValue) String() string

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"`
	AllowOutOfOrderDelivery *bool          `protobuf:"varint,4,opt,name=allowOutOfOrderDelivery,def=0" json:"allowOutOfOrderDelivery,omitempty"`
	// contains filtered or unexported fields
}

func (*KeySharedMeta) Descriptor deprecated

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

Deprecated: Use KeySharedMeta.ProtoReflect.Descriptor instead.

func (*KeySharedMeta) GetAllowOutOfOrderDelivery

func (x *KeySharedMeta) GetAllowOutOfOrderDelivery() bool

func (*KeySharedMeta) GetHashRanges

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

func (*KeySharedMeta) GetKeySharedMode

func (x *KeySharedMeta) GetKeySharedMode() KeySharedMode

func (*KeySharedMeta) ProtoMessage

func (*KeySharedMeta) ProtoMessage()

func (*KeySharedMeta) ProtoReflect added in v0.10.0

func (x *KeySharedMeta) ProtoReflect() protoreflect.Message

func (*KeySharedMeta) Reset

func (x *KeySharedMeta) Reset()

func (*KeySharedMeta) String

func (x *KeySharedMeta) String() string

type KeySharedMode

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

func (KeySharedMode) Descriptor added in v0.10.0

func (KeySharedMode) Enum

func (x KeySharedMode) Enum() *KeySharedMode

func (KeySharedMode) EnumDescriptor deprecated

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

Deprecated: Use KeySharedMode.Descriptor instead.

func (KeySharedMode) Number added in v0.10.0

func (KeySharedMode) String

func (x KeySharedMode) String() string

func (KeySharedMode) Type added in v0.10.0

func (*KeySharedMode) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// contains filtered or unexported fields
}

func (*KeyValue) Descriptor deprecated

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

Deprecated: Use KeyValue.ProtoReflect.Descriptor instead.

func (*KeyValue) GetKey

func (x *KeyValue) GetKey() string

func (*KeyValue) GetValue

func (x *KeyValue) GetValue() string

func (*KeyValue) ProtoMessage

func (*KeyValue) ProtoMessage()

func (*KeyValue) ProtoReflect added in v0.10.0

func (x *KeyValue) ProtoReflect() protoreflect.Message

func (*KeyValue) Reset

func (x *KeyValue) Reset()

func (*KeyValue) String

func (x *KeyValue) String() string

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"`
	AckSet     []int64 `protobuf:"varint,5,rep,name=ack_set,json=ackSet" json:"ack_set,omitempty"`
	BatchSize  *int32  `protobuf:"varint,6,opt,name=batch_size,json=batchSize" json:"batch_size,omitempty"`
	// For the chunk message id, we need to specify the first chunk message id.
	FirstChunkMessageId *MessageIdData `protobuf:"bytes,7,opt,name=first_chunk_message_id,json=firstChunkMessageId" json:"first_chunk_message_id,omitempty"`
	// contains filtered or unexported fields
}

func (*MessageIdData) Descriptor deprecated

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

Deprecated: Use MessageIdData.ProtoReflect.Descriptor instead.

func (*MessageIdData) GetAckSet added in v0.6.0

func (x *MessageIdData) GetAckSet() []int64

func (*MessageIdData) GetBatchIndex

func (x *MessageIdData) GetBatchIndex() int32

func (*MessageIdData) GetBatchSize added in v0.6.0

func (x *MessageIdData) GetBatchSize() int32

func (*MessageIdData) GetEntryId

func (x *MessageIdData) GetEntryId() uint64

func (*MessageIdData) GetFirstChunkMessageId added in v0.9.0

func (x *MessageIdData) GetFirstChunkMessageId() *MessageIdData

func (*MessageIdData) GetLedgerId

func (x *MessageIdData) GetLedgerId() uint64

func (*MessageIdData) GetPartition

func (x *MessageIdData) GetPartition() int32

func (*MessageIdData) ProtoMessage

func (*MessageIdData) ProtoMessage()

func (*MessageIdData) ProtoReflect added in v0.10.0

func (x *MessageIdData) ProtoReflect() protoreflect.Message

func (*MessageIdData) Reset

func (x *MessageIdData) Reset()

func (*MessageIdData) String

func (x *MessageIdData) String() string

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" json:"txnid_least_bits,omitempty"`
	TxnidMostBits  *uint64 `protobuf:"varint,23,opt,name=txnid_most_bits,json=txnidMostBits" 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"`
	// Indicate if the message payload value is set
	NullValue         *bool   `protobuf:"varint,25,opt,name=null_value,json=nullValue,def=0" json:"null_value,omitempty"`
	Uuid              *string `protobuf:"bytes,26,opt,name=uuid" json:"uuid,omitempty"`
	NumChunksFromMsg  *int32  `protobuf:"varint,27,opt,name=num_chunks_from_msg,json=numChunksFromMsg" json:"num_chunks_from_msg,omitempty"`
	TotalChunkMsgSize *int32  `protobuf:"varint,28,opt,name=total_chunk_msg_size,json=totalChunkMsgSize" json:"total_chunk_msg_size,omitempty"`
	ChunkId           *int32  `protobuf:"varint,29,opt,name=chunk_id,json=chunkId" json:"chunk_id,omitempty"`
	// Indicate if the message partition key is set
	NullPartitionKey *bool `protobuf:"varint,30,opt,name=null_partition_key,json=nullPartitionKey,def=0" json:"null_partition_key,omitempty"`
	// contains filtered or unexported fields
}

func (*MessageMetadata) Descriptor deprecated

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

Deprecated: Use MessageMetadata.ProtoReflect.Descriptor instead.

func (*MessageMetadata) GetChunkId added in v0.6.0

func (x *MessageMetadata) GetChunkId() int32

func (*MessageMetadata) GetCompression

func (x *MessageMetadata) GetCompression() CompressionType

func (*MessageMetadata) GetDeliverAtTime

func (x *MessageMetadata) GetDeliverAtTime() int64

func (*MessageMetadata) GetEncryptionAlgo

func (x *MessageMetadata) GetEncryptionAlgo() string

func (*MessageMetadata) GetEncryptionKeys

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

func (*MessageMetadata) GetEncryptionParam

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

func (*MessageMetadata) GetEventTime

func (x *MessageMetadata) GetEventTime() uint64

func (*MessageMetadata) GetHighestSequenceId

func (x *MessageMetadata) GetHighestSequenceId() uint64

func (*MessageMetadata) GetMarkerType

func (x *MessageMetadata) GetMarkerType() int32

func (*MessageMetadata) GetNullPartitionKey added in v0.6.0

func (x *MessageMetadata) GetNullPartitionKey() bool

func (*MessageMetadata) GetNullValue added in v0.6.0

func (x *MessageMetadata) GetNullValue() bool

func (*MessageMetadata) GetNumChunksFromMsg added in v0.6.0

func (x *MessageMetadata) GetNumChunksFromMsg() int32

func (*MessageMetadata) GetNumMessagesInBatch

func (x *MessageMetadata) GetNumMessagesInBatch() int32

func (*MessageMetadata) GetOrderingKey

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

func (*MessageMetadata) GetPartitionKey

func (x *MessageMetadata) GetPartitionKey() string

func (*MessageMetadata) GetPartitionKeyB64Encoded

func (x *MessageMetadata) GetPartitionKeyB64Encoded() bool

func (*MessageMetadata) GetProducerName

func (x *MessageMetadata) GetProducerName() string

func (*MessageMetadata) GetProperties

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

func (*MessageMetadata) GetPublishTime

func (x *MessageMetadata) GetPublishTime() uint64

func (*MessageMetadata) GetReplicateTo

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

func (*MessageMetadata) GetReplicatedFrom

func (x *MessageMetadata) GetReplicatedFrom() string

func (*MessageMetadata) GetSchemaVersion

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

func (*MessageMetadata) GetSequenceId

func (x *MessageMetadata) GetSequenceId() uint64

func (*MessageMetadata) GetTotalChunkMsgSize added in v0.6.0

func (x *MessageMetadata) GetTotalChunkMsgSize() int32

func (*MessageMetadata) GetTxnidLeastBits

func (x *MessageMetadata) GetTxnidLeastBits() uint64

func (*MessageMetadata) GetTxnidMostBits

func (x *MessageMetadata) GetTxnidMostBits() uint64

func (*MessageMetadata) GetUncompressedSize

func (x *MessageMetadata) GetUncompressedSize() uint32

func (*MessageMetadata) GetUuid added in v0.6.0

func (x *MessageMetadata) GetUuid() string

func (*MessageMetadata) ProtoMessage

func (*MessageMetadata) ProtoMessage()

func (*MessageMetadata) ProtoReflect added in v0.10.0

func (x *MessageMetadata) ProtoReflect() protoreflect.Message

func (*MessageMetadata) Reset

func (x *MessageMetadata) Reset()

func (*MessageMetadata) String

func (x *MessageMetadata) String() string

type ProducerAccessMode added in v0.6.0

type ProducerAccessMode int32
const (
	ProducerAccessMode_Shared               ProducerAccessMode = 0 // By default multiple producers can publish on a topic
	ProducerAccessMode_Exclusive            ProducerAccessMode = 1 // Require exclusive access for producer. Fail immediately if there's already a producer connected.
	ProducerAccessMode_WaitForExclusive     ProducerAccessMode = 2 // Producer creation is pending until it can acquire exclusive access
	ProducerAccessMode_ExclusiveWithFencing ProducerAccessMode = 3 // Require exclusive access for producer. Fence out old producer.
)

func (ProducerAccessMode) Descriptor added in v0.10.0

func (ProducerAccessMode) Enum added in v0.6.0

func (ProducerAccessMode) EnumDescriptor deprecated added in v0.6.0

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

Deprecated: Use ProducerAccessMode.Descriptor instead.

func (ProducerAccessMode) Number added in v0.10.0

func (ProducerAccessMode) String added in v0.6.0

func (x ProducerAccessMode) String() string

func (ProducerAccessMode) Type added in v0.10.0

func (*ProducerAccessMode) UnmarshalJSON deprecated added in v0.6.0

func (x *ProducerAccessMode) UnmarshalJSON(b []byte) error

Deprecated: Do not use.

type ProtocolVersion

type ProtocolVersion int32

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

const (
	ProtocolVersion_v0  ProtocolVersion = 0  // Initial versioning
	ProtocolVersion_v1  ProtocolVersion = 1  // Added application keep-alive
	ProtocolVersion_v2  ProtocolVersion = 2  // Added RedeliverUnacknowledgedMessages Command
	ProtocolVersion_v3  ProtocolVersion = 3  // Added compression with LZ4 and ZLib
	ProtocolVersion_v4  ProtocolVersion = 4  // Added batch message support
	ProtocolVersion_v5  ProtocolVersion = 5  // Added disconnect client w/o closing connection
	ProtocolVersion_v6  ProtocolVersion = 6  // Added checksum computation for metadata + payload
	ProtocolVersion_v7  ProtocolVersion = 7  // Added CommandLookupTopic - Binary Lookup
	ProtocolVersion_v8  ProtocolVersion = 8  // Added CommandConsumerStats - Client fetches broker side consumer stats
	ProtocolVersion_v9  ProtocolVersion = 9  // Added end of topic notification
	ProtocolVersion_v10 ProtocolVersion = 10 // Added proxy to broker
	ProtocolVersion_v11 ProtocolVersion = 11 // C++ consumers before this version are not correctly handling the checksum field
	ProtocolVersion_v12 ProtocolVersion = 12 // Added get topic's last messageId from broker
	// Added CommandActiveConsumerChange
	// Added CommandGetTopicsOfNamespace
	ProtocolVersion_v13 ProtocolVersion = 13 // Schema-registry : added avro schema format for json
	ProtocolVersion_v14 ProtocolVersion = 14 // Add CommandAuthChallenge and CommandAuthResponse for mutual auth
	// Added Key_Shared subscription
	ProtocolVersion_v15 ProtocolVersion = 15 // Add CommandGetOrCreateSchema and CommandGetOrCreateSchemaResponse
	ProtocolVersion_v16 ProtocolVersion = 16 // Add support for broker entry metadata
	ProtocolVersion_v17 ProtocolVersion = 17 // Added support ack receipt
	ProtocolVersion_v18 ProtocolVersion = 18 // Add client support for broker entry metadata
	ProtocolVersion_v19 ProtocolVersion = 19 // Add CommandTcClientConnectRequest and CommandTcClientConnectResponse
)

func (ProtocolVersion) Descriptor added in v0.10.0

func (ProtocolVersion) Enum

func (x ProtocolVersion) Enum() *ProtocolVersion

func (ProtocolVersion) EnumDescriptor deprecated

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

Deprecated: Use ProtocolVersion.Descriptor instead.

func (ProtocolVersion) Number added in v0.10.0

func (ProtocolVersion) String

func (x ProtocolVersion) String() string

func (ProtocolVersion) Type added in v0.10.0

func (*ProtocolVersion) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// contains filtered or unexported fields
}

func (*Schema) Descriptor deprecated

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

Deprecated: Use Schema.ProtoReflect.Descriptor instead.

func (*Schema) GetName

func (x *Schema) GetName() string

func (*Schema) GetProperties

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

func (*Schema) GetSchemaData

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

func (*Schema) GetType

func (x *Schema) GetType() Schema_Type

func (*Schema) ProtoMessage

func (*Schema) ProtoMessage()

func (*Schema) ProtoReflect added in v0.10.0

func (x *Schema) ProtoReflect() protoreflect.Message

func (*Schema) Reset

func (x *Schema) Reset()

func (*Schema) String

func (x *Schema) String() string

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
	Schema_Instant        Schema_Type = 16
	Schema_LocalDate      Schema_Type = 17
	Schema_LocalTime      Schema_Type = 18
	Schema_LocalDateTime  Schema_Type = 19
	Schema_ProtobufNative Schema_Type = 20
)

func (Schema_Type) Descriptor added in v0.10.0

func (Schema_Type) Enum

func (x Schema_Type) Enum() *Schema_Type

func (Schema_Type) EnumDescriptor deprecated

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

Deprecated: Use Schema_Type.Descriptor instead.

func (Schema_Type) Number added in v0.10.0

func (x Schema_Type) Number() protoreflect.EnumNumber

func (Schema_Type) String

func (x Schema_Type) String() string

func (Schema_Type) Type added in v0.10.0

func (*Schema_Type) UnmarshalJSON deprecated

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

Deprecated: Do not use.

type ServerError

type ServerError int32
const (
	ServerError_UnknownError        ServerError = 0
	ServerError_MetadataError       ServerError = 1 // Error with ZK/metadata
	ServerError_PersistenceError    ServerError = 2 // Error writing reading from BK
	ServerError_AuthenticationError ServerError = 3 // Non valid authentication
	ServerError_AuthorizationError  ServerError = 4 // Not authorized to use resource
	ServerError_ConsumerBusy        ServerError = 5 // Unable to subscribe/unsubscribe because
	// other consumers are connected
	ServerError_ServiceNotReady                       ServerError = 6  // Any error that requires client retry operation with a fresh lookup
	ServerError_ProducerBlockedQuotaExceededError     ServerError = 7  // Unable to create producer because backlog quota exceeded
	ServerError_ProducerBlockedQuotaExceededException ServerError = 8  // Exception while creating producer because quota exceeded
	ServerError_ChecksumError                         ServerError = 9  // Error while verifying message checksum
	ServerError_UnsupportedVersionError               ServerError = 10 // Error when an older client/version doesn't support a required feature
	ServerError_TopicNotFound                         ServerError = 11 // Topic not found
	ServerError_SubscriptionNotFound                  ServerError = 12 // Subscription not found
	ServerError_ConsumerNotFound                      ServerError = 13 // Consumer not found
	ServerError_TooManyRequests                       ServerError = 14 // Error with too many simultaneously request
	ServerError_TopicTerminatedError                  ServerError = 15 // The topic has been terminated
	ServerError_ProducerBusy                          ServerError = 16 // Producer with same name is already connected
	ServerError_InvalidTopicName                      ServerError = 17 // The topic name is not valid
	ServerError_IncompatibleSchema                    ServerError = 18 // Specified schema was incompatible with topic schema
	ServerError_ConsumerAssignError                   ServerError = 19 // Dispatcher assign consumer error
	ServerError_TransactionCoordinatorNotFound        ServerError = 20 // Transaction coordinator not found error
	ServerError_InvalidTxnStatus                      ServerError = 21 // Invalid txn status error
	ServerError_NotAllowedError                       ServerError = 22 // Not allowed error
	ServerError_TransactionConflict                   ServerError = 23 // Ack with transaction conflict
	ServerError_TransactionNotFound                   ServerError = 24 // Transaction not found
	ServerError_ProducerFenced                        ServerError = 25 // When a producer asks and fail to get exclusive producer access,
)

func (ServerError) Descriptor added in v0.10.0

func (ServerError) Enum

func (x ServerError) Enum() *ServerError

func (ServerError) EnumDescriptor deprecated

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

Deprecated: Use ServerError.Descriptor instead.

func (ServerError) Number added in v0.10.0

func (x ServerError) Number() protoreflect.EnumNumber

func (ServerError) String

func (x ServerError) String() string

func (ServerError) Type added in v0.10.0

func (*ServerError) UnmarshalJSON deprecated

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

Deprecated: Do not use.

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"`
	// Indicate if the message payload value is set
	NullValue *bool `protobuf:"varint,9,opt,name=null_value,json=nullValue,def=0" json:"null_value,omitempty"`
	// Indicate if the message partition key is set
	NullPartitionKey *bool `protobuf:"varint,10,opt,name=null_partition_key,json=nullPartitionKey,def=0" json:"null_partition_key,omitempty"`
	// contains filtered or unexported fields
}

func (*SingleMessageMetadata) Descriptor deprecated

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

Deprecated: Use SingleMessageMetadata.ProtoReflect.Descriptor instead.

func (*SingleMessageMetadata) GetCompactedOut

func (x *SingleMessageMetadata) GetCompactedOut() bool

func (*SingleMessageMetadata) GetEventTime

func (x *SingleMessageMetadata) GetEventTime() uint64

func (*SingleMessageMetadata) GetNullPartitionKey added in v0.6.0

func (x *SingleMessageMetadata) GetNullPartitionKey() bool

func (*SingleMessageMetadata) GetNullValue added in v0.6.0

func (x *SingleMessageMetadata) GetNullValue() bool

func (*SingleMessageMetadata) GetOrderingKey

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

func (*SingleMessageMetadata) GetPartitionKey

func (x *SingleMessageMetadata) GetPartitionKey() string

func (*SingleMessageMetadata) GetPartitionKeyB64Encoded

func (x *SingleMessageMetadata) GetPartitionKeyB64Encoded() bool

func (*SingleMessageMetadata) GetPayloadSize

func (x *SingleMessageMetadata) GetPayloadSize() int32

func (*SingleMessageMetadata) GetProperties

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

func (*SingleMessageMetadata) GetSequenceId

func (x *SingleMessageMetadata) GetSequenceId() uint64

func (*SingleMessageMetadata) ProtoMessage

func (*SingleMessageMetadata) ProtoMessage()

func (*SingleMessageMetadata) ProtoReflect added in v0.10.0

func (x *SingleMessageMetadata) ProtoReflect() protoreflect.Message

func (*SingleMessageMetadata) Reset

func (x *SingleMessageMetadata) Reset()

func (*SingleMessageMetadata) String

func (x *SingleMessageMetadata) String() string

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"`
	// contains filtered or unexported fields
}

func (*Subscription) Descriptor deprecated

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

Deprecated: Use Subscription.ProtoReflect.Descriptor instead.

func (*Subscription) GetSubscription

func (x *Subscription) GetSubscription() string

func (*Subscription) GetTopic

func (x *Subscription) GetTopic() string

func (*Subscription) ProtoMessage

func (*Subscription) ProtoMessage()

func (*Subscription) ProtoReflect added in v0.10.0

func (x *Subscription) ProtoReflect() protoreflect.Message

func (*Subscription) Reset

func (x *Subscription) Reset()

func (*Subscription) String

func (x *Subscription) String() string

type TxnAction

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

func (TxnAction) Descriptor added in v0.10.0

func (TxnAction) Descriptor() protoreflect.EnumDescriptor

func (TxnAction) Enum

func (x TxnAction) Enum() *TxnAction

func (TxnAction) EnumDescriptor deprecated

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

Deprecated: Use TxnAction.Descriptor instead.

func (TxnAction) Number added in v0.10.0

func (x TxnAction) Number() protoreflect.EnumNumber

func (TxnAction) String

func (x TxnAction) String() string

func (TxnAction) Type added in v0.10.0

func (*TxnAction) UnmarshalJSON deprecated

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

Deprecated: Do not use.

Jump to

Keyboard shortcuts

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