records

package
v0.0.185 Latest Latest
Warning

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

Go to latest
Published: Mar 13, 2024 License: Apache-2.0 Imports: 4 Imported by: 31

Documentation

Index

Constants

This section is empty.

Variables

View Source
var File_records_ps_records_activemq_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_aws_kinesis_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_aws_sqs_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_azure_event_hub_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_azure_service_bus_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_base_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_gcp_pubsub_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_kafka_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_kubemq_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_memphis_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_mongo_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_mqtt_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_nats_jetstream_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_nats_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_nats_streaming_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_nsq_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_postgres_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_pulsar_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_rabbit_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_rabbit_streams_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_redis_pubsub_proto protoreflect.FileDescriptor
View Source
var File_records_ps_records_redis_streams_proto protoreflect.FileDescriptor

Functions

This section is empty.

Types

type AWSKinesis added in v0.0.121

type AWSKinesis struct {
	PartitionKey   string `protobuf:"bytes,1,opt,name=partition_key,json=partitionKey,proto3" json:"partition_key,omitempty"`
	SequenceNumber string `protobuf:"bytes,2,opt,name=sequence_number,json=sequenceNumber,proto3" json:"sequence_number,omitempty"`
	EncryptionType string `protobuf:"bytes,3,opt,name=encryption_type,json=encryptionType,proto3" json:"encryption_type,omitempty"`
	ShardId        string `protobuf:"bytes,4,opt,name=shard_id,json=shardId,proto3" json:"shard_id,omitempty"`
	Value          []byte `protobuf:"bytes,5,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*AWSKinesis) Descriptor deprecated added in v0.0.121

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

Deprecated: Use AWSKinesis.ProtoReflect.Descriptor instead.

func (*AWSKinesis) GetEncryptionType added in v0.0.121

func (x *AWSKinesis) GetEncryptionType() string

func (*AWSKinesis) GetPartitionKey added in v0.0.121

func (x *AWSKinesis) GetPartitionKey() string

func (*AWSKinesis) GetSequenceNumber added in v0.0.121

func (x *AWSKinesis) GetSequenceNumber() string

func (*AWSKinesis) GetShardId added in v0.0.121

func (x *AWSKinesis) GetShardId() string

func (*AWSKinesis) GetValue added in v0.0.121

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

func (*AWSKinesis) ProtoMessage added in v0.0.121

func (*AWSKinesis) ProtoMessage()

func (*AWSKinesis) ProtoReflect added in v0.0.181

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

func (*AWSKinesis) Reset added in v0.0.121

func (x *AWSKinesis) Reset()

func (*AWSKinesis) String added in v0.0.121

func (x *AWSKinesis) String() string

type AWSSQS added in v0.0.77

type AWSSQS struct {
	Id              string            `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	Timestamp       int64             `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	RecipientHandle string            `protobuf:"bytes,3,opt,name=recipient_handle,json=recipientHandle,proto3" json:"recipient_handle,omitempty"`
	Attributes      map[string]string `` /* 161-byte string literal not displayed */
	Value           []byte            `protobuf:"bytes,5,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*AWSSQS) Descriptor deprecated added in v0.0.77

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

Deprecated: Use AWSSQS.ProtoReflect.Descriptor instead.

func (*AWSSQS) GetAttributes added in v0.0.77

func (x *AWSSQS) GetAttributes() map[string]string

func (*AWSSQS) GetId added in v0.0.77

func (x *AWSSQS) GetId() string

func (*AWSSQS) GetRecipientHandle added in v0.0.77

func (x *AWSSQS) GetRecipientHandle() string

func (*AWSSQS) GetTimestamp added in v0.0.77

func (x *AWSSQS) GetTimestamp() int64

func (*AWSSQS) GetValue added in v0.0.77

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

func (*AWSSQS) ProtoMessage added in v0.0.77

func (*AWSSQS) ProtoMessage()

func (*AWSSQS) ProtoReflect added in v0.0.181

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

func (*AWSSQS) Reset added in v0.0.77

func (x *AWSSQS) Reset()

func (*AWSSQS) String added in v0.0.77

func (x *AWSSQS) String() string

type ActiveMQ added in v0.0.77

type ActiveMQ struct {
	Destination    string `protobuf:"bytes,1,opt,name=destination,proto3" json:"destination,omitempty"`
	ContentType    string `protobuf:"bytes,2,opt,name=content_type,json=contentType,proto3" json:"content_type,omitempty"`
	SubscriptionId string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	Timestamp      int64  `protobuf:"varint,4,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Value          []byte `protobuf:"bytes,5,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*ActiveMQ) Descriptor deprecated added in v0.0.77

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

Deprecated: Use ActiveMQ.ProtoReflect.Descriptor instead.

func (*ActiveMQ) GetContentType added in v0.0.77

func (x *ActiveMQ) GetContentType() string

func (*ActiveMQ) GetDestination added in v0.0.77

func (x *ActiveMQ) GetDestination() string

func (*ActiveMQ) GetSubscriptionId added in v0.0.77

func (x *ActiveMQ) GetSubscriptionId() string

func (*ActiveMQ) GetTimestamp added in v0.0.77

func (x *ActiveMQ) GetTimestamp() int64

func (*ActiveMQ) GetValue added in v0.0.77

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

func (*ActiveMQ) ProtoMessage added in v0.0.77

func (*ActiveMQ) ProtoMessage()

func (*ActiveMQ) ProtoReflect added in v0.0.181

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

func (*ActiveMQ) Reset added in v0.0.77

func (x *ActiveMQ) Reset()

func (*ActiveMQ) String added in v0.0.77

func (x *ActiveMQ) String() string

type AzureEventHub added in v0.0.77

type AzureEventHub struct {
	Id               string            `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	SystemProperties map[string]string `` /* 197-byte string literal not displayed */
	Timestamp        int64             `protobuf:"varint,3,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Value            []byte            `protobuf:"bytes,4,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*AzureEventHub) Descriptor deprecated added in v0.0.77

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

Deprecated: Use AzureEventHub.ProtoReflect.Descriptor instead.

func (*AzureEventHub) GetId added in v0.0.77

func (x *AzureEventHub) GetId() string

func (*AzureEventHub) GetSystemProperties added in v0.0.77

func (x *AzureEventHub) GetSystemProperties() map[string]string

func (*AzureEventHub) GetTimestamp added in v0.0.77

func (x *AzureEventHub) GetTimestamp() int64

func (*AzureEventHub) GetValue added in v0.0.77

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

func (*AzureEventHub) ProtoMessage added in v0.0.77

func (*AzureEventHub) ProtoMessage()

func (*AzureEventHub) ProtoReflect added in v0.0.181

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

func (*AzureEventHub) Reset added in v0.0.77

func (x *AzureEventHub) Reset()

func (*AzureEventHub) String added in v0.0.77

func (x *AzureEventHub) String() string

type AzureServiceBus added in v0.0.77

type AzureServiceBus struct {
	ContentType      string                 `protobuf:"bytes,1,opt,name=content_type,json=contentType,proto3" json:"content_type,omitempty"`
	CorrelationId    string                 `protobuf:"bytes,2,opt,name=correlation_id,json=correlationId,proto3" json:"correlation_id,omitempty"`
	Value            []byte                 `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	DeliveryCount    uint32                 `protobuf:"varint,4,opt,name=delivery_count,json=deliveryCount,proto3" json:"delivery_count,omitempty"`
	SessionId        string                 `protobuf:"bytes,5,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	GroupSequence    uint32                 `protobuf:"varint,6,opt,name=group_sequence,json=groupSequence,proto3" json:"group_sequence,omitempty"`
	Id               string                 `protobuf:"bytes,7,opt,name=id,proto3" json:"id,omitempty"`
	Label            string                 `protobuf:"bytes,8,opt,name=label,proto3" json:"label,omitempty"`
	ReplyTo          string                 `protobuf:"bytes,9,opt,name=reply_to,json=replyTo,proto3" json:"reply_to,omitempty"`
	ReplyToGroupId   string                 `protobuf:"bytes,10,opt,name=reply_to_group_id,json=replyToGroupId,proto3" json:"reply_to_group_id,omitempty"`
	To               string                 `protobuf:"bytes,11,opt,name=to,proto3" json:"to,omitempty"`
	Ttl              int64                  `protobuf:"varint,12,opt,name=ttl,proto3" json:"ttl,omitempty"`
	LockToken        string                 `protobuf:"bytes,13,opt,name=lock_token,json=lockToken,proto3" json:"lock_token,omitempty"`
	SystemProperties *AzureSystemProperties `protobuf:"bytes,14,opt,name=system_properties,json=systemProperties,proto3" json:"system_properties,omitempty"`
	UserProperties   map[string]string      `` /* 192-byte string literal not displayed */
	Format           uint32                 `protobuf:"varint,16,opt,name=format,proto3" json:"format,omitempty"`
	// contains filtered or unexported fields
}

func (*AzureServiceBus) Descriptor deprecated added in v0.0.77

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

Deprecated: Use AzureServiceBus.ProtoReflect.Descriptor instead.

func (*AzureServiceBus) GetContentType added in v0.0.77

func (x *AzureServiceBus) GetContentType() string

func (*AzureServiceBus) GetCorrelationId added in v0.0.77

func (x *AzureServiceBus) GetCorrelationId() string

func (*AzureServiceBus) GetDeliveryCount added in v0.0.77

func (x *AzureServiceBus) GetDeliveryCount() uint32

func (*AzureServiceBus) GetFormat added in v0.0.77

func (x *AzureServiceBus) GetFormat() uint32

func (*AzureServiceBus) GetGroupSequence added in v0.0.77

func (x *AzureServiceBus) GetGroupSequence() uint32

func (*AzureServiceBus) GetId added in v0.0.77

func (x *AzureServiceBus) GetId() string

func (*AzureServiceBus) GetLabel added in v0.0.77

func (x *AzureServiceBus) GetLabel() string

func (*AzureServiceBus) GetLockToken added in v0.0.77

func (x *AzureServiceBus) GetLockToken() string

func (*AzureServiceBus) GetReplyTo added in v0.0.77

func (x *AzureServiceBus) GetReplyTo() string

func (*AzureServiceBus) GetReplyToGroupId added in v0.0.77

func (x *AzureServiceBus) GetReplyToGroupId() string

func (*AzureServiceBus) GetSessionId added in v0.0.77

func (x *AzureServiceBus) GetSessionId() string

func (*AzureServiceBus) GetSystemProperties added in v0.0.77

func (x *AzureServiceBus) GetSystemProperties() *AzureSystemProperties

func (*AzureServiceBus) GetTo added in v0.0.77

func (x *AzureServiceBus) GetTo() string

func (*AzureServiceBus) GetTtl added in v0.0.77

func (x *AzureServiceBus) GetTtl() int64

func (*AzureServiceBus) GetUserProperties added in v0.0.77

func (x *AzureServiceBus) GetUserProperties() map[string]string

func (*AzureServiceBus) GetValue added in v0.0.77

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

func (*AzureServiceBus) ProtoMessage added in v0.0.77

func (*AzureServiceBus) ProtoMessage()

func (*AzureServiceBus) ProtoReflect added in v0.0.181

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

func (*AzureServiceBus) Reset added in v0.0.77

func (x *AzureServiceBus) Reset()

func (*AzureServiceBus) String added in v0.0.77

func (x *AzureServiceBus) String() string

type AzureSystemProperties added in v0.0.77

type AzureSystemProperties struct {
	LockedUntil            int64             `protobuf:"varint,1,opt,name=locked_until,json=lockedUntil,proto3" json:"locked_until,omitempty"`
	SequenceNumber         int64             `protobuf:"varint,2,opt,name=sequence_number,json=sequenceNumber,proto3" json:"sequence_number,omitempty"`
	PartitionId            int32             `protobuf:"varint,3,opt,name=partition_id,json=partitionId,proto3" json:"partition_id,omitempty"`
	PartitionKey           string            `protobuf:"bytes,4,opt,name=partition_key,json=partitionKey,proto3" json:"partition_key,omitempty"`
	EnqueuedTime           int64             `protobuf:"varint,5,opt,name=enqueued_time,json=enqueuedTime,proto3" json:"enqueued_time,omitempty"`
	DeadLetterSource       string            `protobuf:"bytes,6,opt,name=dead_letter_source,json=deadLetterSource,proto3" json:"dead_letter_source,omitempty"`
	ScheduledEnqueueTime   int64             `protobuf:"varint,7,opt,name=scheduled_enqueue_time,json=scheduledEnqueueTime,proto3" json:"scheduled_enqueue_time,omitempty"`
	EnqueuedSequenceNumber int64             `` /* 130-byte string literal not displayed */
	ViaPartitionKey        string            `protobuf:"bytes,9,opt,name=via_partition_key,json=viaPartitionKey,proto3" json:"via_partition_key,omitempty"`
	Annotations            map[string]string `` /* 164-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*AzureSystemProperties) Descriptor deprecated added in v0.0.77

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

Deprecated: Use AzureSystemProperties.ProtoReflect.Descriptor instead.

func (*AzureSystemProperties) GetAnnotations added in v0.0.77

func (x *AzureSystemProperties) GetAnnotations() map[string]string

func (*AzureSystemProperties) GetDeadLetterSource added in v0.0.77

func (x *AzureSystemProperties) GetDeadLetterSource() string

func (*AzureSystemProperties) GetEnqueuedSequenceNumber added in v0.0.77

func (x *AzureSystemProperties) GetEnqueuedSequenceNumber() int64

func (*AzureSystemProperties) GetEnqueuedTime added in v0.0.77

func (x *AzureSystemProperties) GetEnqueuedTime() int64

func (*AzureSystemProperties) GetLockedUntil added in v0.0.77

func (x *AzureSystemProperties) GetLockedUntil() int64

func (*AzureSystemProperties) GetPartitionId added in v0.0.77

func (x *AzureSystemProperties) GetPartitionId() int32

func (*AzureSystemProperties) GetPartitionKey added in v0.0.77

func (x *AzureSystemProperties) GetPartitionKey() string

func (*AzureSystemProperties) GetScheduledEnqueueTime added in v0.0.77

func (x *AzureSystemProperties) GetScheduledEnqueueTime() int64

func (*AzureSystemProperties) GetSequenceNumber added in v0.0.77

func (x *AzureSystemProperties) GetSequenceNumber() int64

func (*AzureSystemProperties) GetViaPartitionKey added in v0.0.77

func (x *AzureSystemProperties) GetViaPartitionKey() string

func (*AzureSystemProperties) ProtoMessage added in v0.0.77

func (*AzureSystemProperties) ProtoMessage()

func (*AzureSystemProperties) ProtoReflect added in v0.0.181

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

func (*AzureSystemProperties) Reset added in v0.0.77

func (x *AzureSystemProperties) Reset()

func (*AzureSystemProperties) String added in v0.0.77

func (x *AzureSystemProperties) String() string

type ErrorRecord added in v0.0.35

type ErrorRecord struct {
	OccurredAtUnixTsUtc int64             `protobuf:"varint,1,opt,name=occurred_at_unix_ts_utc,json=occurredAtUnixTsUtc,proto3" json:"occurred_at_unix_ts_utc,omitempty"`
	Error               string            `protobuf:"bytes,2,opt,name=error,proto3" json:"error,omitempty"`
	Metadata            map[string][]byte `` /* 157-byte string literal not displayed */
	// contains filtered or unexported fields
}

Used for communicating errors that occur during a read, write, relay, etc.

func (*ErrorRecord) Descriptor deprecated added in v0.0.35

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

Deprecated: Use ErrorRecord.ProtoReflect.Descriptor instead.

func (*ErrorRecord) GetError added in v0.0.35

func (x *ErrorRecord) GetError() string

func (*ErrorRecord) GetMetadata added in v0.0.35

func (x *ErrorRecord) GetMetadata() map[string][]byte

func (*ErrorRecord) GetOccurredAtUnixTsUtc added in v0.0.35

func (x *ErrorRecord) GetOccurredAtUnixTsUtc() int64

func (*ErrorRecord) ProtoMessage added in v0.0.35

func (*ErrorRecord) ProtoMessage()

func (*ErrorRecord) ProtoReflect added in v0.0.181

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

func (*ErrorRecord) Reset added in v0.0.35

func (x *ErrorRecord) Reset()

func (*ErrorRecord) String added in v0.0.35

func (x *ErrorRecord) String() string

type GCPPubSub added in v0.0.77

type GCPPubSub struct {
	Id              string            `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	Value           []byte            `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	Attributes      map[string]string `` /* 161-byte string literal not displayed */
	PublishTime     int64             `protobuf:"varint,4,opt,name=publish_time,json=publishTime,proto3" json:"publish_time,omitempty"`
	DeliveryAttempt int32             `protobuf:"varint,5,opt,name=delivery_attempt,json=deliveryAttempt,proto3" json:"delivery_attempt,omitempty"`
	OrderingKey     string            `protobuf:"bytes,6,opt,name=ordering_key,json=orderingKey,proto3" json:"ordering_key,omitempty"`
	// contains filtered or unexported fields
}

func (*GCPPubSub) Descriptor deprecated added in v0.0.77

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

Deprecated: Use GCPPubSub.ProtoReflect.Descriptor instead.

func (*GCPPubSub) GetAttributes added in v0.0.77

func (x *GCPPubSub) GetAttributes() map[string]string

func (*GCPPubSub) GetDeliveryAttempt added in v0.0.77

func (x *GCPPubSub) GetDeliveryAttempt() int32

func (*GCPPubSub) GetId added in v0.0.77

func (x *GCPPubSub) GetId() string

func (*GCPPubSub) GetOrderingKey added in v0.0.77

func (x *GCPPubSub) GetOrderingKey() string

func (*GCPPubSub) GetPublishTime added in v0.0.77

func (x *GCPPubSub) GetPublishTime() int64

func (*GCPPubSub) GetValue added in v0.0.77

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

func (*GCPPubSub) ProtoMessage added in v0.0.77

func (*GCPPubSub) ProtoMessage()

func (*GCPPubSub) ProtoReflect added in v0.0.181

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

func (*GCPPubSub) Reset added in v0.0.77

func (x *GCPPubSub) Reset()

func (*GCPPubSub) String added in v0.0.77

func (x *GCPPubSub) String() string

type IsReadRecord_Record added in v0.0.51

type IsReadRecord_Record = isReadRecord_Record

type Kafka

type Kafka struct {
	Topic     string         `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	Key       []byte         `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
	Value     []byte         `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64          `protobuf:"varint,4,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Offset    int64          `protobuf:"varint,5,opt,name=offset,proto3" json:"offset,omitempty"`
	Partition int32          `protobuf:"varint,6,opt,name=partition,proto3" json:"partition,omitempty"`
	Headers   []*KafkaHeader `protobuf:"bytes,7,rep,name=headers,proto3" json:"headers,omitempty"`
	// contains filtered or unexported fields
}

func (*Kafka) Descriptor deprecated

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

Deprecated: Use Kafka.ProtoReflect.Descriptor instead.

func (*Kafka) GetHeaders

func (x *Kafka) GetHeaders() []*KafkaHeader

func (*Kafka) GetKey

func (x *Kafka) GetKey() []byte

func (*Kafka) GetOffset

func (x *Kafka) GetOffset() int64

func (*Kafka) GetPartition

func (x *Kafka) GetPartition() int32

func (*Kafka) GetTimestamp

func (x *Kafka) GetTimestamp() int64

func (*Kafka) GetTopic

func (x *Kafka) GetTopic() string

func (*Kafka) GetValue

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

func (*Kafka) ProtoMessage

func (*Kafka) ProtoMessage()

func (*Kafka) ProtoReflect added in v0.0.181

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

func (*Kafka) Reset

func (x *Kafka) Reset()

func (*Kafka) String

func (x *Kafka) String() string

type KafkaHeader

type KafkaHeader struct {
	Key   string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value string `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*KafkaHeader) Descriptor deprecated

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

Deprecated: Use KafkaHeader.ProtoReflect.Descriptor instead.

func (*KafkaHeader) GetKey

func (x *KafkaHeader) GetKey() string

func (*KafkaHeader) GetValue

func (x *KafkaHeader) GetValue() string

func (*KafkaHeader) ProtoMessage

func (*KafkaHeader) ProtoMessage()

func (*KafkaHeader) ProtoReflect added in v0.0.181

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

func (*KafkaHeader) Reset

func (x *KafkaHeader) Reset()

func (*KafkaHeader) String

func (x *KafkaHeader) String() string

type KubeMQ added in v0.0.77

type KubeMQ struct {
	Id        string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	ClientId  string `protobuf:"bytes,2,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	Channel   string `protobuf:"bytes,3,opt,name=channel,proto3" json:"channel,omitempty"`
	Value     []byte `protobuf:"bytes,4,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64  `protobuf:"varint,5,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Sequence  int64  `protobuf:"varint,6,opt,name=sequence,proto3" json:"sequence,omitempty"`
	// contains filtered or unexported fields
}

func (*KubeMQ) Descriptor deprecated added in v0.0.77

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

Deprecated: Use KubeMQ.ProtoReflect.Descriptor instead.

func (*KubeMQ) GetChannel added in v0.0.77

func (x *KubeMQ) GetChannel() string

func (*KubeMQ) GetClientId added in v0.0.77

func (x *KubeMQ) GetClientId() string

func (*KubeMQ) GetId added in v0.0.77

func (x *KubeMQ) GetId() string

func (*KubeMQ) GetSequence added in v0.0.77

func (x *KubeMQ) GetSequence() int64

func (*KubeMQ) GetTimestamp added in v0.0.77

func (x *KubeMQ) GetTimestamp() int64

func (*KubeMQ) GetValue added in v0.0.77

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

func (*KubeMQ) ProtoMessage added in v0.0.77

func (*KubeMQ) ProtoMessage()

func (*KubeMQ) ProtoReflect added in v0.0.181

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

func (*KubeMQ) Reset added in v0.0.77

func (x *KubeMQ) Reset()

func (*KubeMQ) String added in v0.0.77

func (x *KubeMQ) String() string

type MQTT added in v0.0.77

type MQTT struct {
	Id        uint32 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	Topic     string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"`
	Value     []byte `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	Duplicate bool   `protobuf:"varint,4,opt,name=duplicate,proto3" json:"duplicate,omitempty"`
	Retained  bool   `protobuf:"varint,5,opt,name=retained,proto3" json:"retained,omitempty"`
	Qos       uint32 `protobuf:"varint,6,opt,name=qos,proto3" json:"qos,omitempty"`
	Timestamp int64  `protobuf:"varint,7,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*MQTT) Descriptor deprecated added in v0.0.77

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

Deprecated: Use MQTT.ProtoReflect.Descriptor instead.

func (*MQTT) GetDuplicate added in v0.0.77

func (x *MQTT) GetDuplicate() bool

func (*MQTT) GetId added in v0.0.77

func (x *MQTT) GetId() uint32

func (*MQTT) GetQos added in v0.0.77

func (x *MQTT) GetQos() uint32

func (*MQTT) GetRetained added in v0.0.77

func (x *MQTT) GetRetained() bool

func (*MQTT) GetTimestamp added in v0.0.77

func (x *MQTT) GetTimestamp() int64

func (*MQTT) GetTopic added in v0.0.77

func (x *MQTT) GetTopic() string

func (*MQTT) GetValue added in v0.0.77

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

func (*MQTT) ProtoMessage added in v0.0.77

func (*MQTT) ProtoMessage()

func (*MQTT) ProtoReflect added in v0.0.181

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

func (*MQTT) Reset added in v0.0.77

func (x *MQTT) Reset()

func (*MQTT) String added in v0.0.77

func (x *MQTT) String() string

type Memphis added in v0.0.177

type Memphis struct {
	Value     []byte `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64  `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*Memphis) Descriptor deprecated added in v0.0.177

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

Deprecated: Use Memphis.ProtoReflect.Descriptor instead.

func (*Memphis) GetTimestamp added in v0.0.177

func (x *Memphis) GetTimestamp() int64

func (*Memphis) GetValue added in v0.0.177

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

func (*Memphis) ProtoMessage added in v0.0.177

func (*Memphis) ProtoMessage()

func (*Memphis) ProtoReflect added in v0.0.181

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

func (*Memphis) Reset added in v0.0.177

func (x *Memphis) Reset()

func (*Memphis) String added in v0.0.177

func (x *Memphis) String() string

type Mongo added in v0.0.77

type Mongo struct {
	Value     []byte `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64  `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*Mongo) Descriptor deprecated added in v0.0.77

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

Deprecated: Use Mongo.ProtoReflect.Descriptor instead.

func (*Mongo) GetTimestamp added in v0.0.77

func (x *Mongo) GetTimestamp() int64

func (*Mongo) GetValue added in v0.0.77

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

func (*Mongo) ProtoMessage added in v0.0.77

func (*Mongo) ProtoMessage()

func (*Mongo) ProtoReflect added in v0.0.181

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

func (*Mongo) Reset added in v0.0.77

func (x *Mongo) Reset()

func (*Mongo) String added in v0.0.77

func (x *Mongo) String() string

type NSQ added in v0.0.77

type NSQ struct {
	Id          string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	Topic       string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"`
	Channel     string `protobuf:"bytes,3,opt,name=channel,proto3" json:"channel,omitempty"`
	Attempts    int32  `protobuf:"varint,4,opt,name=attempts,proto3" json:"attempts,omitempty"`
	NsqdAddress string `protobuf:"bytes,5,opt,name=nsqd_address,json=nsqdAddress,proto3" json:"nsqd_address,omitempty"`
	Value       []byte `protobuf:"bytes,6,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp   int64  `protobuf:"varint,7,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*NSQ) Descriptor deprecated added in v0.0.77

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

Deprecated: Use NSQ.ProtoReflect.Descriptor instead.

func (*NSQ) GetAttempts added in v0.0.77

func (x *NSQ) GetAttempts() int32

func (*NSQ) GetChannel added in v0.0.77

func (x *NSQ) GetChannel() string

func (*NSQ) GetId added in v0.0.77

func (x *NSQ) GetId() string

func (*NSQ) GetNsqdAddress added in v0.0.77

func (x *NSQ) GetNsqdAddress() string

func (*NSQ) GetTimestamp added in v0.0.77

func (x *NSQ) GetTimestamp() int64

func (*NSQ) GetTopic added in v0.0.77

func (x *NSQ) GetTopic() string

func (*NSQ) GetValue added in v0.0.77

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

func (*NSQ) ProtoMessage added in v0.0.77

func (*NSQ) ProtoMessage()

func (*NSQ) ProtoReflect added in v0.0.181

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

func (*NSQ) Reset added in v0.0.77

func (x *NSQ) Reset()

func (*NSQ) String added in v0.0.77

func (x *NSQ) String() string

type Nats added in v0.0.77

type Nats struct {
	Subject string `protobuf:"bytes,1,opt,name=subject,proto3" json:"subject,omitempty"`
	Value   []byte `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*Nats) Descriptor deprecated added in v0.0.77

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

Deprecated: Use Nats.ProtoReflect.Descriptor instead.

func (*Nats) GetSubject added in v0.0.77

func (x *Nats) GetSubject() string

func (*Nats) GetValue added in v0.0.77

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

func (*Nats) ProtoMessage added in v0.0.77

func (*Nats) ProtoMessage()

func (*Nats) ProtoReflect added in v0.0.181

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

func (*Nats) Reset added in v0.0.77

func (x *Nats) Reset()

func (*Nats) String added in v0.0.77

func (x *Nats) String() string

type NatsJetstream added in v0.0.119

type NatsJetstream struct {
	Stream       string `protobuf:"bytes,1,opt,name=stream,proto3" json:"stream,omitempty"`
	Value        []byte `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	ConsumerName string `protobuf:"bytes,3,opt,name=consumer_name,json=consumerName,proto3" json:"consumer_name,omitempty"`
	Sequence     int64  `protobuf:"varint,4,opt,name=sequence,proto3" json:"sequence,omitempty"`
	// contains filtered or unexported fields
}

func (*NatsJetstream) Descriptor deprecated added in v0.0.119

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

Deprecated: Use NatsJetstream.ProtoReflect.Descriptor instead.

func (*NatsJetstream) GetConsumerName added in v0.0.163

func (x *NatsJetstream) GetConsumerName() string

func (*NatsJetstream) GetSequence added in v0.0.163

func (x *NatsJetstream) GetSequence() int64

func (*NatsJetstream) GetStream added in v0.0.119

func (x *NatsJetstream) GetStream() string

func (*NatsJetstream) GetValue added in v0.0.119

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

func (*NatsJetstream) ProtoMessage added in v0.0.119

func (*NatsJetstream) ProtoMessage()

func (*NatsJetstream) ProtoReflect added in v0.0.181

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

func (*NatsJetstream) Reset added in v0.0.119

func (x *NatsJetstream) Reset()

func (*NatsJetstream) String added in v0.0.119

func (x *NatsJetstream) String() string

type NatsStreaming added in v0.0.77

type NatsStreaming struct {
	Metadata  map[string]string `` /* 157-byte string literal not displayed */
	Value     []byte            `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64             `protobuf:"varint,3,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*NatsStreaming) Descriptor deprecated added in v0.0.77

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

Deprecated: Use NatsStreaming.ProtoReflect.Descriptor instead.

func (*NatsStreaming) GetMetadata added in v0.0.77

func (x *NatsStreaming) GetMetadata() map[string]string

func (*NatsStreaming) GetTimestamp added in v0.0.77

func (x *NatsStreaming) GetTimestamp() int64

func (*NatsStreaming) GetValue added in v0.0.77

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

func (*NatsStreaming) ProtoMessage added in v0.0.77

func (*NatsStreaming) ProtoMessage()

func (*NatsStreaming) ProtoReflect added in v0.0.181

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

func (*NatsStreaming) Reset added in v0.0.77

func (x *NatsStreaming) Reset()

func (*NatsStreaming) String added in v0.0.77

func (x *NatsStreaming) String() string

type Postgres added in v0.0.77

type Postgres struct {
	Metadata  map[string]string `` /* 157-byte string literal not displayed */
	Timestamp int64             `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Value     []byte            `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*Postgres) Descriptor deprecated added in v0.0.77

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

Deprecated: Use Postgres.ProtoReflect.Descriptor instead.

func (*Postgres) GetMetadata added in v0.0.77

func (x *Postgres) GetMetadata() map[string]string

func (*Postgres) GetTimestamp added in v0.0.77

func (x *Postgres) GetTimestamp() int64

func (*Postgres) GetValue added in v0.0.77

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

func (*Postgres) ProtoMessage added in v0.0.77

func (*Postgres) ProtoMessage()

func (*Postgres) ProtoReflect added in v0.0.181

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

func (*Postgres) Reset added in v0.0.77

func (x *Postgres) Reset()

func (*Postgres) String added in v0.0.77

func (x *Postgres) String() string

type Pulsar added in v0.0.77

type Pulsar struct {
	Id              string            `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	Key             string            `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
	Topic           string            `protobuf:"bytes,3,opt,name=topic,proto3" json:"topic,omitempty"`
	Properties      map[string]string `` /* 161-byte string literal not displayed */
	RedeliveryCount uint32            `protobuf:"varint,5,opt,name=redelivery_count,json=redeliveryCount,proto3" json:"redelivery_count,omitempty"`
	EventTime       string            `protobuf:"bytes,6,opt,name=event_time,json=eventTime,proto3" json:"event_time,omitempty"`
	IsReplicated    bool              `protobuf:"varint,7,opt,name=is_replicated,json=isReplicated,proto3" json:"is_replicated,omitempty"`
	OrderingKey     string            `protobuf:"bytes,8,opt,name=ordering_key,json=orderingKey,proto3" json:"ordering_key,omitempty"`
	ProducerName    string            `protobuf:"bytes,9,opt,name=producer_name,json=producerName,proto3" json:"producer_name,omitempty"`
	PublishTime     string            `protobuf:"bytes,10,opt,name=publish_time,json=publishTime,proto3" json:"publish_time,omitempty"`
	Timestamp       int64             `protobuf:"varint,11,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Value           []byte            `protobuf:"bytes,12,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*Pulsar) Descriptor deprecated added in v0.0.77

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

Deprecated: Use Pulsar.ProtoReflect.Descriptor instead.

func (*Pulsar) GetEventTime added in v0.0.77

func (x *Pulsar) GetEventTime() string

func (*Pulsar) GetId added in v0.0.77

func (x *Pulsar) GetId() string

func (*Pulsar) GetIsReplicated added in v0.0.77

func (x *Pulsar) GetIsReplicated() bool

func (*Pulsar) GetKey added in v0.0.77

func (x *Pulsar) GetKey() string

func (*Pulsar) GetOrderingKey added in v0.0.77

func (x *Pulsar) GetOrderingKey() string

func (*Pulsar) GetProducerName added in v0.0.77

func (x *Pulsar) GetProducerName() string

func (*Pulsar) GetProperties added in v0.0.77

func (x *Pulsar) GetProperties() map[string]string

func (*Pulsar) GetPublishTime added in v0.0.77

func (x *Pulsar) GetPublishTime() string

func (*Pulsar) GetRedeliveryCount added in v0.0.77

func (x *Pulsar) GetRedeliveryCount() uint32

func (*Pulsar) GetTimestamp added in v0.0.77

func (x *Pulsar) GetTimestamp() int64

func (*Pulsar) GetTopic added in v0.0.77

func (x *Pulsar) GetTopic() string

func (*Pulsar) GetValue added in v0.0.77

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

func (*Pulsar) ProtoMessage added in v0.0.77

func (*Pulsar) ProtoMessage()

func (*Pulsar) ProtoReflect added in v0.0.181

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

func (*Pulsar) Reset added in v0.0.77

func (x *Pulsar) Reset()

func (*Pulsar) String added in v0.0.77

func (x *Pulsar) String() string

type Rabbit added in v0.0.77

type Rabbit struct {
	Body            []byte          `protobuf:"bytes,1,opt,name=body,proto3" json:"body,omitempty"`
	Timestamp       int64           `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Type            string          `protobuf:"bytes,3,opt,name=type,proto3" json:"type,omitempty"`
	Exchange        string          `protobuf:"bytes,4,opt,name=exchange,proto3" json:"exchange,omitempty"`
	RoutingKey      string          `protobuf:"bytes,5,opt,name=routing_key,json=routingKey,proto3" json:"routing_key,omitempty"`
	ContentType     string          `protobuf:"bytes,6,opt,name=content_type,json=contentType,proto3" json:"content_type,omitempty"`
	ContentEncoding string          `protobuf:"bytes,7,opt,name=content_encoding,json=contentEncoding,proto3" json:"content_encoding,omitempty"`
	Priority        int32           `protobuf:"varint,8,opt,name=priority,proto3" json:"priority,omitempty"`
	Expiration      string          `protobuf:"bytes,9,opt,name=expiration,proto3" json:"expiration,omitempty"`
	MessageId       string          `protobuf:"bytes,10,opt,name=message_id,json=messageId,proto3" json:"message_id,omitempty"`
	UserId          string          `protobuf:"bytes,11,opt,name=user_id,json=userId,proto3" json:"user_id,omitempty"`
	AppId           string          `protobuf:"bytes,12,opt,name=app_id,json=appId,proto3" json:"app_id,omitempty"`
	ReplyTo         string          `protobuf:"bytes,13,opt,name=reply_to,json=replyTo,proto3" json:"reply_to,omitempty"`
	CorrelationId   string          `protobuf:"bytes,14,opt,name=correlation_id,json=correlationId,proto3" json:"correlation_id,omitempty"`
	Headers         []*RabbitHeader `protobuf:"bytes,15,rep,name=headers,proto3" json:"headers,omitempty"`
	// contains filtered or unexported fields
}

func (*Rabbit) Descriptor deprecated added in v0.0.77

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

Deprecated: Use Rabbit.ProtoReflect.Descriptor instead.

func (*Rabbit) GetAppId added in v0.0.77

func (x *Rabbit) GetAppId() string

func (*Rabbit) GetBody added in v0.0.77

func (x *Rabbit) GetBody() []byte

func (*Rabbit) GetContentEncoding added in v0.0.77

func (x *Rabbit) GetContentEncoding() string

func (*Rabbit) GetContentType added in v0.0.77

func (x *Rabbit) GetContentType() string

func (*Rabbit) GetCorrelationId added in v0.0.77

func (x *Rabbit) GetCorrelationId() string

func (*Rabbit) GetExchange added in v0.0.77

func (x *Rabbit) GetExchange() string

func (*Rabbit) GetExpiration added in v0.0.77

func (x *Rabbit) GetExpiration() string

func (*Rabbit) GetHeaders added in v0.0.77

func (x *Rabbit) GetHeaders() []*RabbitHeader

func (*Rabbit) GetMessageId added in v0.0.77

func (x *Rabbit) GetMessageId() string

func (*Rabbit) GetPriority added in v0.0.77

func (x *Rabbit) GetPriority() int32

func (*Rabbit) GetReplyTo added in v0.0.77

func (x *Rabbit) GetReplyTo() string

func (*Rabbit) GetRoutingKey added in v0.0.77

func (x *Rabbit) GetRoutingKey() string

func (*Rabbit) GetTimestamp added in v0.0.77

func (x *Rabbit) GetTimestamp() int64

func (*Rabbit) GetType added in v0.0.77

func (x *Rabbit) GetType() string

func (*Rabbit) GetUserId added in v0.0.77

func (x *Rabbit) GetUserId() string

func (*Rabbit) ProtoMessage added in v0.0.77

func (*Rabbit) ProtoMessage()

func (*Rabbit) ProtoReflect added in v0.0.181

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

func (*Rabbit) Reset added in v0.0.77

func (x *Rabbit) Reset()

func (*Rabbit) String added in v0.0.77

func (x *Rabbit) String() string

type RabbitHeader added in v0.0.77

type RabbitHeader struct {
	Key   string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value string `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*RabbitHeader) Descriptor deprecated added in v0.0.77

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

Deprecated: Use RabbitHeader.ProtoReflect.Descriptor instead.

func (*RabbitHeader) GetKey added in v0.0.77

func (x *RabbitHeader) GetKey() string

func (*RabbitHeader) GetValue added in v0.0.77

func (x *RabbitHeader) GetValue() string

func (*RabbitHeader) ProtoMessage added in v0.0.77

func (*RabbitHeader) ProtoMessage()

func (*RabbitHeader) ProtoReflect added in v0.0.181

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

func (*RabbitHeader) Reset added in v0.0.77

func (x *RabbitHeader) Reset()

func (*RabbitHeader) String added in v0.0.77

func (x *RabbitHeader) String() string

type RabbitStreams added in v0.0.77

type RabbitStreams struct {
	DeliveryTag         string               `protobuf:"bytes,1,opt,name=delivery_tag,json=deliveryTag,proto3" json:"delivery_tag,omitempty"`
	Format              uint32               `protobuf:"varint,2,opt,name=format,proto3" json:"format,omitempty"`
	Header              *RabbitStreamsHeader `protobuf:"bytes,3,opt,name=header,proto3" json:"header,omitempty"`
	DeliveryAnnotations map[string]string    `` /* 206-byte string literal not displayed */
	SendSettled         bool                 `protobuf:"varint,5,opt,name=send_settled,json=sendSettled,proto3" json:"send_settled,omitempty"`
	StreamName          string               `protobuf:"bytes,6,opt,name=stream_name,json=streamName,proto3" json:"stream_name,omitempty"`
	Timestamp           int64                `protobuf:"varint,7,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Value               []byte               `protobuf:"bytes,8,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*RabbitStreams) Descriptor deprecated added in v0.0.77

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

Deprecated: Use RabbitStreams.ProtoReflect.Descriptor instead.

func (*RabbitStreams) GetDeliveryAnnotations added in v0.0.77

func (x *RabbitStreams) GetDeliveryAnnotations() map[string]string

func (*RabbitStreams) GetDeliveryTag added in v0.0.77

func (x *RabbitStreams) GetDeliveryTag() string

func (*RabbitStreams) GetFormat added in v0.0.77

func (x *RabbitStreams) GetFormat() uint32

func (*RabbitStreams) GetHeader added in v0.0.77

func (x *RabbitStreams) GetHeader() *RabbitStreamsHeader

func (*RabbitStreams) GetSendSettled added in v0.0.77

func (x *RabbitStreams) GetSendSettled() bool

func (*RabbitStreams) GetStreamName added in v0.0.77

func (x *RabbitStreams) GetStreamName() string

func (*RabbitStreams) GetTimestamp added in v0.0.77

func (x *RabbitStreams) GetTimestamp() int64

func (*RabbitStreams) GetValue added in v0.0.77

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

func (*RabbitStreams) ProtoMessage added in v0.0.77

func (*RabbitStreams) ProtoMessage()

func (*RabbitStreams) ProtoReflect added in v0.0.181

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

func (*RabbitStreams) Reset added in v0.0.77

func (x *RabbitStreams) Reset()

func (*RabbitStreams) String added in v0.0.77

func (x *RabbitStreams) String() string

type RabbitStreamsHeader added in v0.0.77

type RabbitStreamsHeader struct {
	Durable       bool   `protobuf:"varint,1,opt,name=durable,proto3" json:"durable,omitempty"`
	Priority      uint32 `protobuf:"varint,2,opt,name=priority,proto3" json:"priority,omitempty"`
	Ttl           int64  `protobuf:"varint,3,opt,name=ttl,proto3" json:"ttl,omitempty"`
	FirstAcquirer bool   `protobuf:"varint,4,opt,name=first_acquirer,json=firstAcquirer,proto3" json:"first_acquirer,omitempty"`
	DeliveryCount uint32 `protobuf:"varint,5,opt,name=delivery_count,json=deliveryCount,proto3" json:"delivery_count,omitempty"`
	// contains filtered or unexported fields
}

func (*RabbitStreamsHeader) Descriptor deprecated added in v0.0.77

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

Deprecated: Use RabbitStreamsHeader.ProtoReflect.Descriptor instead.

func (*RabbitStreamsHeader) GetDeliveryCount added in v0.0.98

func (x *RabbitStreamsHeader) GetDeliveryCount() uint32

func (*RabbitStreamsHeader) GetDurable added in v0.0.98

func (x *RabbitStreamsHeader) GetDurable() bool

func (*RabbitStreamsHeader) GetFirstAcquirer added in v0.0.98

func (x *RabbitStreamsHeader) GetFirstAcquirer() bool

func (*RabbitStreamsHeader) GetPriority added in v0.0.98

func (x *RabbitStreamsHeader) GetPriority() uint32

func (*RabbitStreamsHeader) GetTtl added in v0.0.98

func (x *RabbitStreamsHeader) GetTtl() int64

func (*RabbitStreamsHeader) ProtoMessage added in v0.0.77

func (*RabbitStreamsHeader) ProtoMessage()

func (*RabbitStreamsHeader) ProtoReflect added in v0.0.181

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

func (*RabbitStreamsHeader) Reset added in v0.0.77

func (x *RabbitStreamsHeader) Reset()

func (*RabbitStreamsHeader) String added in v0.0.77

func (x *RabbitStreamsHeader) String() string

type ReadRecord added in v0.0.34

type ReadRecord struct {

	// Unique id automatically created by plumber
	MessageId string `protobuf:"bytes,1,opt,name=message_id,json=messageId,proto3" json:"message_id,omitempty"`
	// Plumber counts the number of messages it reads; this number represents
	// the message number (useful for CLI).
	Num int64 `protobuf:"varint,3,opt,name=num,proto3" json:"num,omitempty"`
	// Metadata may contain properties that cannot be found in the Raw message.
	// For example: read lag in Kafka.
	//
	// Metadata may also contain data such as "count" which is an incremental
	// number that plumber assigns to each message it receives. This is used
	// with read via CLI functionality to allow the user to quickly discern
	// whether this is message #1 or #500, etc.
	Metadata map[string]string `` /* 157-byte string literal not displayed */
	// UTC unix timestamp of when plumber received the message; a backend record
	// entry might have its own timestamp as well. This should be seconds.
	ReceivedAtUnixTsUtc int64 `protobuf:"varint,6,opt,name=received_at_unix_ts_utc,json=receivedAtUnixTsUtc,proto3" json:"received_at_unix_ts_utc,omitempty"`
	// Set _outside_ the backend; will contain the final value, regardless of
	// whether decoding options were specified for a read.
	// _This_ is what both CLI and desktop should display for the payload.
	Payload []byte `protobuf:"bytes,99,opt,name=payload,proto3" json:"payload,omitempty"`
	// Types that are assignable to Record:
	//
	//	*ReadRecord_Kafka
	//	*ReadRecord_Rabbit
	//	*ReadRecord_Activemq
	//	*ReadRecord_AwsSqs
	//	*ReadRecord_AzureEventHub
	//	*ReadRecord_AzureServiceBus
	//	*ReadRecord_GcpPubsub
	//	*ReadRecord_Kubemq
	//	*ReadRecord_Mongo
	//	*ReadRecord_Mqtt
	//	*ReadRecord_Nats
	//	*ReadRecord_NatsStreaming
	//	*ReadRecord_Nsq
	//	*ReadRecord_Postgres
	//	*ReadRecord_Pulsar
	//	*ReadRecord_RabbitStreams
	//	*ReadRecord_RedisPubsub
	//	*ReadRecord_RedisStreams
	//	*ReadRecord_NatsJetstream
	//	*ReadRecord_AwsKinesis
	//	*ReadRecord_Memphis
	Record isReadRecord_Record `protobuf_oneof:"Record"`
	// Original backend message (encoded with gob, ie. *skafka.Message, etc.).
	// In most cases, you should use the oneof record instead of the raw message.
	XRaw []byte `protobuf:"bytes,1000,opt,name=_raw,json=Raw,proto3" json:"_raw,omitempty"`
	// Identifies which plumber instance received the event (set outside the backend)
	XPlumberId string `protobuf:"bytes,1001,opt,name=_plumber_id,json=PlumberId,proto3" json:"_plumber_id,omitempty"`
	// contains filtered or unexported fields
}

Returned for read requests (server & cli)

func (*ReadRecord) Descriptor deprecated added in v0.0.34

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

Deprecated: Use ReadRecord.ProtoReflect.Descriptor instead.

func (*ReadRecord) GetActivemq added in v0.0.77

func (x *ReadRecord) GetActivemq() *ActiveMQ

func (*ReadRecord) GetAwsKinesis added in v0.0.121

func (x *ReadRecord) GetAwsKinesis() *AWSKinesis

func (*ReadRecord) GetAwsSqs added in v0.0.114

func (x *ReadRecord) GetAwsSqs() *AWSSQS

func (*ReadRecord) GetAzureEventHub added in v0.0.77

func (x *ReadRecord) GetAzureEventHub() *AzureEventHub

func (*ReadRecord) GetAzureServiceBus added in v0.0.77

func (x *ReadRecord) GetAzureServiceBus() *AzureServiceBus

func (*ReadRecord) GetGcpPubsub added in v0.0.77

func (x *ReadRecord) GetGcpPubsub() *GCPPubSub

func (*ReadRecord) GetKafka added in v0.0.34

func (x *ReadRecord) GetKafka() *Kafka

func (*ReadRecord) GetKubemq added in v0.0.77

func (x *ReadRecord) GetKubemq() *KubeMQ

func (*ReadRecord) GetMemphis added in v0.0.177

func (x *ReadRecord) GetMemphis() *Memphis

func (*ReadRecord) GetMessageId added in v0.0.34

func (x *ReadRecord) GetMessageId() string

func (*ReadRecord) GetMetadata added in v0.0.34

func (x *ReadRecord) GetMetadata() map[string]string

func (*ReadRecord) GetMongo added in v0.0.77

func (x *ReadRecord) GetMongo() *Mongo

func (*ReadRecord) GetMqtt added in v0.0.77

func (x *ReadRecord) GetMqtt() *MQTT

func (*ReadRecord) GetNats added in v0.0.77

func (x *ReadRecord) GetNats() *Nats

func (*ReadRecord) GetNatsJetstream added in v0.0.119

func (x *ReadRecord) GetNatsJetstream() *NatsJetstream

func (*ReadRecord) GetNatsStreaming added in v0.0.77

func (x *ReadRecord) GetNatsStreaming() *NatsStreaming

func (*ReadRecord) GetNsq added in v0.0.77

func (x *ReadRecord) GetNsq() *NSQ

func (*ReadRecord) GetNum added in v0.0.51

func (x *ReadRecord) GetNum() int64

func (*ReadRecord) GetPayload added in v0.0.51

func (x *ReadRecord) GetPayload() []byte

func (*ReadRecord) GetPostgres added in v0.0.77

func (x *ReadRecord) GetPostgres() *Postgres

func (*ReadRecord) GetPulsar added in v0.0.77

func (x *ReadRecord) GetPulsar() *Pulsar

func (*ReadRecord) GetRabbit added in v0.0.77

func (x *ReadRecord) GetRabbit() *Rabbit

func (*ReadRecord) GetRabbitStreams added in v0.0.77

func (x *ReadRecord) GetRabbitStreams() *RabbitStreams

func (*ReadRecord) GetReceivedAtUnixTsUtc added in v0.0.35

func (x *ReadRecord) GetReceivedAtUnixTsUtc() int64

func (*ReadRecord) GetRecord added in v0.0.34

func (m *ReadRecord) GetRecord() isReadRecord_Record

func (*ReadRecord) GetRedisPubsub added in v0.0.77

func (x *ReadRecord) GetRedisPubsub() *RedisPubsub

func (*ReadRecord) GetRedisStreams added in v0.0.77

func (x *ReadRecord) GetRedisStreams() *RedisStreams

func (*ReadRecord) GetXPlumberId added in v0.0.51

func (x *ReadRecord) GetXPlumberId() string

func (*ReadRecord) GetXRaw added in v0.0.51

func (x *ReadRecord) GetXRaw() []byte

func (*ReadRecord) ProtoMessage added in v0.0.34

func (*ReadRecord) ProtoMessage()

func (*ReadRecord) ProtoReflect added in v0.0.181

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

func (*ReadRecord) Reset added in v0.0.34

func (x *ReadRecord) Reset()

func (*ReadRecord) String added in v0.0.34

func (x *ReadRecord) String() string

type ReadRecord_Activemq added in v0.0.77

type ReadRecord_Activemq struct {
	Activemq *ActiveMQ `protobuf:"bytes,102,opt,name=activemq,proto3,oneof"`
}

type ReadRecord_AwsKinesis added in v0.0.121

type ReadRecord_AwsKinesis struct {
	AwsKinesis *AWSKinesis `protobuf:"bytes,119,opt,name=aws_kinesis,json=awsKinesis,proto3,oneof"`
}

type ReadRecord_AwsSqs added in v0.0.114

type ReadRecord_AwsSqs struct {
	AwsSqs *AWSSQS `protobuf:"bytes,103,opt,name=aws_sqs,json=awsSqs,proto3,oneof"`
}

type ReadRecord_AzureEventHub added in v0.0.77

type ReadRecord_AzureEventHub struct {
	AzureEventHub *AzureEventHub `protobuf:"bytes,104,opt,name=azure_event_hub,json=azureEventHub,proto3,oneof"`
}

type ReadRecord_AzureServiceBus added in v0.0.77

type ReadRecord_AzureServiceBus struct {
	AzureServiceBus *AzureServiceBus `protobuf:"bytes,105,opt,name=azure_service_bus,json=azureServiceBus,proto3,oneof"`
}

type ReadRecord_GcpPubsub added in v0.0.77

type ReadRecord_GcpPubsub struct {
	GcpPubsub *GCPPubSub `protobuf:"bytes,106,opt,name=gcp_pubsub,json=gcpPubsub,proto3,oneof"`
}

type ReadRecord_Kafka added in v0.0.34

type ReadRecord_Kafka struct {
	Kafka *Kafka `protobuf:"bytes,100,opt,name=kafka,proto3,oneof"`
}

type ReadRecord_Kubemq added in v0.0.77

type ReadRecord_Kubemq struct {
	Kubemq *KubeMQ `protobuf:"bytes,107,opt,name=kubemq,proto3,oneof"`
}

type ReadRecord_Memphis added in v0.0.177

type ReadRecord_Memphis struct {
	Memphis *Memphis `protobuf:"bytes,120,opt,name=memphis,proto3,oneof"`
}

type ReadRecord_Mongo added in v0.0.77

type ReadRecord_Mongo struct {
	Mongo *Mongo `protobuf:"bytes,108,opt,name=mongo,proto3,oneof"`
}

type ReadRecord_Mqtt added in v0.0.77

type ReadRecord_Mqtt struct {
	Mqtt *MQTT `protobuf:"bytes,109,opt,name=mqtt,proto3,oneof"`
}

type ReadRecord_Nats added in v0.0.77

type ReadRecord_Nats struct {
	Nats *Nats `protobuf:"bytes,110,opt,name=nats,proto3,oneof"`
}

type ReadRecord_NatsJetstream added in v0.0.119

type ReadRecord_NatsJetstream struct {
	NatsJetstream *NatsJetstream `protobuf:"bytes,118,opt,name=nats_jetstream,json=natsJetstream,proto3,oneof"`
}

type ReadRecord_NatsStreaming added in v0.0.77

type ReadRecord_NatsStreaming struct {
	NatsStreaming *NatsStreaming `protobuf:"bytes,111,opt,name=nats_streaming,json=natsStreaming,proto3,oneof"`
}

type ReadRecord_Nsq added in v0.0.77

type ReadRecord_Nsq struct {
	Nsq *NSQ `protobuf:"bytes,112,opt,name=nsq,proto3,oneof"`
}

type ReadRecord_Postgres added in v0.0.77

type ReadRecord_Postgres struct {
	Postgres *Postgres `protobuf:"bytes,113,opt,name=postgres,proto3,oneof"`
}

type ReadRecord_Pulsar added in v0.0.77

type ReadRecord_Pulsar struct {
	Pulsar *Pulsar `protobuf:"bytes,114,opt,name=pulsar,proto3,oneof"`
}

type ReadRecord_Rabbit added in v0.0.77

type ReadRecord_Rabbit struct {
	Rabbit *Rabbit `protobuf:"bytes,101,opt,name=rabbit,proto3,oneof"`
}

type ReadRecord_RabbitStreams added in v0.0.77

type ReadRecord_RabbitStreams struct {
	RabbitStreams *RabbitStreams `protobuf:"bytes,115,opt,name=rabbit_streams,json=rabbitStreams,proto3,oneof"`
}

type ReadRecord_RedisPubsub added in v0.0.77

type ReadRecord_RedisPubsub struct {
	RedisPubsub *RedisPubsub `protobuf:"bytes,116,opt,name=redis_pubsub,json=redisPubsub,proto3,oneof"`
}

type ReadRecord_RedisStreams added in v0.0.77

type ReadRecord_RedisStreams struct {
	RedisStreams *RedisStreams `protobuf:"bytes,117,opt,name=redis_streams,json=redisStreams,proto3,oneof"`
}

type RedisPubsub added in v0.0.77

type RedisPubsub struct {
	Metadata  map[string]string `` /* 157-byte string literal not displayed */
	Value     []byte            `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	Timestamp int64             `protobuf:"varint,3,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*RedisPubsub) Descriptor deprecated added in v0.0.77

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

Deprecated: Use RedisPubsub.ProtoReflect.Descriptor instead.

func (*RedisPubsub) GetMetadata added in v0.0.77

func (x *RedisPubsub) GetMetadata() map[string]string

func (*RedisPubsub) GetTimestamp added in v0.0.77

func (x *RedisPubsub) GetTimestamp() int64

func (*RedisPubsub) GetValue added in v0.0.77

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

func (*RedisPubsub) ProtoMessage added in v0.0.77

func (*RedisPubsub) ProtoMessage()

func (*RedisPubsub) ProtoReflect added in v0.0.181

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

func (*RedisPubsub) Reset added in v0.0.77

func (x *RedisPubsub) Reset()

func (*RedisPubsub) String added in v0.0.77

func (x *RedisPubsub) String() string

type RedisStreams added in v0.0.77

type RedisStreams struct {
	Id        string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	Key       string `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
	Value     string `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	Stream    string `protobuf:"bytes,4,opt,name=stream,proto3" json:"stream,omitempty"`
	Timestamp int64  `protobuf:"varint,5,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

func (*RedisStreams) Descriptor deprecated added in v0.0.77

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

Deprecated: Use RedisStreams.ProtoReflect.Descriptor instead.

func (*RedisStreams) GetId added in v0.0.77

func (x *RedisStreams) GetId() string

func (*RedisStreams) GetKey added in v0.0.77

func (x *RedisStreams) GetKey() string

func (*RedisStreams) GetStream added in v0.0.77

func (x *RedisStreams) GetStream() string

func (*RedisStreams) GetTimestamp added in v0.0.77

func (x *RedisStreams) GetTimestamp() int64

func (*RedisStreams) GetValue added in v0.0.77

func (x *RedisStreams) GetValue() string

func (*RedisStreams) ProtoMessage added in v0.0.77

func (*RedisStreams) ProtoMessage()

func (*RedisStreams) ProtoReflect added in v0.0.181

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

func (*RedisStreams) Reset added in v0.0.77

func (x *RedisStreams) Reset()

func (*RedisStreams) String added in v0.0.77

func (x *RedisStreams) String() string

type WriteRecord added in v0.0.34

type WriteRecord struct {

	// If encoding options are provided, this value will be updated by plumber
	// to contain the encoded payload _before_ passing it to the backend.
	// @gotags: kong:"help='Input string',name=input,xor=input,default"
	Input string `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty" kong:"help='Input string',name=input,xor=input,default"`
	// @gotags: kong:"help='Optional metadata a backend may use (key1=value,key2=value,etc)',name=input-metadata"
	InputMetadata map[string]string `` /* 286-byte string literal not displayed */
	// contains filtered or unexported fields
}

Used as an arg for write requests (server & cli)

func (*WriteRecord) Descriptor deprecated added in v0.0.34

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

Deprecated: Use WriteRecord.ProtoReflect.Descriptor instead.

func (*WriteRecord) GetInput added in v0.0.46

func (x *WriteRecord) GetInput() string

func (*WriteRecord) GetInputMetadata added in v0.0.46

func (x *WriteRecord) GetInputMetadata() map[string]string

func (*WriteRecord) ProtoMessage added in v0.0.34

func (*WriteRecord) ProtoMessage()

func (*WriteRecord) ProtoReflect added in v0.0.181

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

func (*WriteRecord) Reset added in v0.0.34

func (x *WriteRecord) Reset()

func (*WriteRecord) String added in v0.0.34

func (x *WriteRecord) String() string

Jump to

Keyboard shortcuts

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