import "github.com/apache/beam/sdks/go/pkg/beam/io/pubsubio/v1"
Package v1 is a generated protocol buffer package.
It is generated from these files:
v1.proto
It has these top-level messages:
PubSubPayload
const PubSubPayloadURN = "beam:go:payload:pubsub:v1"
PubSubPayloadURN is the URN of the pubsub proto payload.
type PubSubPayload struct { Op PubSubPayload_Op `protobuf:"varint,1,opt,name=op,enum=v1.PubSubPayload_Op" json:"op,omitempty"` Topic string `protobuf:"bytes,2,opt,name=Topic" json:"Topic,omitempty"` Subscription string `protobuf:"bytes,3,opt,name=Subscription" json:"Subscription,omitempty"` IdAttribute string `protobuf:"bytes,4,opt,name=IdAttribute" json:"IdAttribute,omitempty"` TimestampAttribute string `protobuf:"bytes,5,opt,name=TimestampAttribute" json:"TimestampAttribute,omitempty"` WithAttributes bool `protobuf:"varint,6,opt,name=WithAttributes" json:"WithAttributes,omitempty"` }
func (*PubSubPayload) Descriptor() ([]byte, []int)
func (m *PubSubPayload) GetIdAttribute() string
func (m *PubSubPayload) GetOp() PubSubPayload_Op
func (m *PubSubPayload) GetSubscription() string
func (m *PubSubPayload) GetTimestampAttribute() string
func (m *PubSubPayload) GetTopic() string
func (m *PubSubPayload) GetWithAttributes() bool
func (*PubSubPayload) ProtoMessage()
func (m *PubSubPayload) Reset()
func (m *PubSubPayload) String() string
const ( PubSubPayload_INVALID PubSubPayload_Op = 0 PubSubPayload_READ PubSubPayload_Op = 1 PubSubPayload_WRITE PubSubPayload_Op = 2 )
func (PubSubPayload_Op) EnumDescriptor() ([]byte, []int)
func (x PubSubPayload_Op) String() string
Package v1 imports 3 packages (graph) and is imported by 2 packages. Updated 2018-04-24. Refresh now. Tools for package owners.