diff --git a/EXAMPLES.md b/EXAMPLES.md index effe9681..e5c67cca 100644 --- a/EXAMPLES.md +++ b/EXAMPLES.md @@ -12,6 +12,7 @@ * [Redis Streams](#redis-streams) * [GCP Pub/Sub](#gcp-pubsub) * [Postgres CDC](#cdc-postgres) + * [MQTT](#mqtt) * [Apache Pulsar](#apache-pulsar) * [Publishing](#publishing) * [AWS SQS](#aws-sqs-1) @@ -25,6 +26,7 @@ * [Redis PubSub](#redis-pubsub-1) * [Redis Streams](#redis-streams-1) * [GCP Pub/Sub](#gcp-pubsub-1) + * [MQTT](#mqtt-1) * [Apache Pulsar](#apache-pulsar-1) * [Relay Mode](#relay-mode) * [Continuously relay messages from your RabbitMQ instance to a Batch.sh collection](#continuously-relay-messages-from-your-rabbitmq-instance-to-a-batchsh-collection) @@ -34,6 +36,7 @@ * [Continuously relay messages for multiple Redis channels to a Batch.sh collection](#continuously-relay-messages-from-multiple-redis-channels-to-a-batchsh-collection) * [Continuously relay messages for multiple Redis streams to a Batch.sh collection](#continuously-relay-messages-from-multiple-redis-streams-to-a-batchsh-collection) * [Continuously relay messages from a Kafka topic (on Confluent) to a Batch.sh collection (via CLI)](#continuously-relay-messages-from-a-kafka-topic-on-confluent-to-a-batchsh-collection-via-cli) + * [Continuously relay messages from a MQTT topic to a Batch.sh collection](#continuously-relay-messages-from-a-mqtt-topic-to-a-batchsh-collection) * [Change Data Capture](#change-data-capture) * [Continuously relay Postgres change events to a Batch.sh collection](#continuously-relay-postgres-change-events-to-a-batchsh-collection) * [Continuously relay MongoDB change stream events to a Batch.sh collection](#continuously-relay-mongodb-change-stream-events-to-a-batchsh-collection) @@ -154,12 +157,18 @@ plumber read redis-pubsub --address="localhost:6379" --channels="new-orders" plumber read redis-streams --address="localhost:6379" --streams="new-orders" ``` -#### GCP Pub/Sub +##### GCP Pub/Sub ```bash plumber read gcp-pubsub --project-id=PROJECT_ID --sub-id=SUBSCRIPTION ``` +##### MQTT + +```bash +plumber read mqtt --address tcp://localhost:1883 --topic iotdata -qos 1 +``` + #### Apache Pulsar ```bash @@ -268,6 +277,11 @@ plumber write redis-streams --address="localhost:6379" --streams="new-orders" -- plumber write gcp-pubsub --topic-id=TOPIC --project-id=PROJECT_ID --input-data='{"Sensor":"Room J","Temp":19}' ``` +##### MQTT + +```bash +plumber write mqtt --address tcp://localhost:1883 --topic iotdata -qos 1 --input-data "{\"id\": 123, \"temperature\": 15}" +``` #### Apache Pulsar ```bash @@ -362,6 +376,19 @@ export PLUMBER_RELAY_KAFKA_SASL_TYPE="plain" $ plumber relay ``` +##### Continuously relay messages from a MQTT topic to a Batch.sh collection + +```bash +docker run -d --name plumber-mqtt -p 8080:8080 \ + -e PLUMBER_RELAY_MQTT_ADDRESS=tcp://localhost:1883 \ + -e PLUMBER_RELAY_MQTT_TOPIC=iotdata \ + -e PLUMBER_RELAY_MQTT_QOS=1 \ + -e PLUMBER_RELAY_TYPE=mqtt \ + -e PLUMBER_RELAY_TOKEN=$YOUR-BATCHSH-TOKEN-HERE \ + batchcorp/plumber +``` + + ## Change Data Capture ##### Continuously relay Postgres change events to a Batch.sh collection diff --git a/backends/mqtt/mqtt.go b/backends/mqtt/mqtt.go index 2dcd2393..0be90af7 100644 --- a/backends/mqtt/mqtt.go +++ b/backends/mqtt/mqtt.go @@ -17,7 +17,13 @@ import ( ) var ( - errInvalidAddress = errors.New("URI scheme must be ssl:// or tcp://") + errInvalidAddress = errors.New("URI scheme must be ssl:// or tcp://") + errMissingAddress = errors.New("--address cannot be empty") + errMissingTopic = errors.New("--topic cannot be empty") + errMissingTLSKey = errors.New("--tls-client-key-file cannot be blank if using ssl") + errMissingTlsCert = errors.New("--tls-client-cert-file cannot be blank if using ssl") + errMissingTLSCA = errors.New("--tls-ca-file cannot be blank if using ssl") + errInvalidQOSLevel = errors.New("QoS level can only be 0, 1 or 2") ) type MQTT struct { diff --git a/backends/mqtt/read.go b/backends/mqtt/read.go index 62b70ea8..afd5b7ee 100644 --- a/backends/mqtt/read.go +++ b/backends/mqtt/read.go @@ -76,7 +76,7 @@ func (m *MQTT) Read() error { func (m *MQTT) subscribe(wg *sync.WaitGroup, errChan chan error) { lineNumber := 1 - m.Client.Subscribe(m.Options.MQTT.Topic, 0, func(client mqtt.Client, msg mqtt.Message) { + m.Client.Subscribe(m.Options.MQTT.Topic, byte(m.Options.MQTT.QoSLevel), func(client mqtt.Client, msg mqtt.Message) { data, err := reader.Decode(m.Options, m.MsgDesc, msg.Payload()) if err != nil { @@ -107,15 +107,6 @@ func (m *MQTT) subscribe(wg *sync.WaitGroup, errChan chan error) { }) } -var ( - errMissingAddress = errors.New("--address cannot be empty") - errMissingTopic = errors.New("--topic cannot be empty") - errMissingTLSKey = errors.New("--tls-client-key-file cannot be blank if using ssl") - errMissingTlsCert = errors.New("--tls-client-cert-file cannot be blank if using ssl") - errMissingTLSCA = errors.New("--tls-ca-file cannot be blank if using ssl") - errInvalidQOSLevel = errors.New("QoS level can only be 0, 1 or 2") -) - func validateReadOptions(opts *cli.Options) error { if opts.MQTT.Address == "" { return errMissingAddress diff --git a/backends/mqtt/relay.go b/backends/mqtt/relay.go index 50c5fed6..f620a1f7 100644 --- a/backends/mqtt/relay.go +++ b/backends/mqtt/relay.go @@ -1,7 +1,157 @@ package mqtt -import "github.com/batchcorp/plumber/cli" +import ( + "context" + "fmt" + "strings" + mqtt "github.com/eclipse/paho.mqtt.golang" + pahomqtt "github.com/eclipse/paho.mqtt.golang" + + "github.com/batchcorp/plumber/api" + "github.com/batchcorp/plumber/backends/mqtt/types" + "github.com/batchcorp/plumber/cli" + "github.com/batchcorp/plumber/relay" + "github.com/batchcorp/plumber/stats" + "github.com/jhump/protoreflect/desc" + "github.com/pkg/errors" + "github.com/relistan/go-director" + "github.com/sirupsen/logrus" +) + +type Relayer struct { + Client pahomqtt.Client + Options *cli.Options + MsgDesc *desc.MessageDescriptor + RelayCh chan interface{} + log *logrus.Entry + Looper *director.FreeLooper + Context context.Context +} + +type IMQTTRelayer interface { + Relay() error +} + +// Relay sets up a new MQTT relayer, starts GRPC workers and the API server func Relay(opts *cli.Options) error { - panic("not implemented") + if err := validateRelayOptions(opts); err != nil { + return errors.Wrap(err, "unable to verify options") + } + + // Create new relayer instance (+ validate token & gRPC address) + relayCfg := &relay.Config{ + Token: opts.RelayToken, + GRPCAddress: opts.RelayGRPCAddress, + NumWorkers: opts.RelayNumWorkers, + Timeout: opts.RelayGRPCTimeout, + RelayCh: make(chan interface{}, 1), + DisableTLS: opts.RelayGRPCDisableTLS, + Type: opts.RelayType, + } + + grpcRelayer, err := relay.New(relayCfg) + if err != nil { + return errors.Wrap(err, "unable to create new gRPC relayer") + } + + // Launch HTTP server + go func() { + if err := api.Start(opts.RelayHTTPListenAddress, opts.Version); err != nil { + logrus.Fatalf("unable to start API server: %s", err) + } + }() + + if err := grpcRelayer.StartWorkers(); err != nil { + return errors.Wrap(err, "unable to start gRPC relay workers") + } + + client, err := connect(opts) + if err != nil { + return errors.Wrap(err, "unable to create client") + } + + r := &Relayer{ + Client: client, + Options: opts, + RelayCh: relayCfg.RelayCh, + log: logrus.WithField("pkg", "mqtt/relay"), + Looper: director.NewFreeLooper(director.FOREVER, make(chan error, 1)), + Context: context.Background(), + } + + return r.Relay() +} + +// validateRelayOptions ensures all required CLI options are present before initializing relay mode +func validateRelayOptions(opts *cli.Options) error { + if opts.MQTT.Address == "" { + return errMissingAddress + } + + if opts.MQTT.Topic == "" { + return errMissingTopic + } + + if strings.HasPrefix(opts.MQTT.Address, "ssl") { + if opts.MQTT.TLSClientKeyFile == "" { + return errMissingTLSKey + } + + if opts.MQTT.TLSClientCertFile == "" { + return errMissingTlsCert + } + + if opts.MQTT.TLSCAFile == "" { + return errMissingTLSCA + } + } + + if opts.MQTT.QoSLevel > 2 || opts.MQTT.QoSLevel < 0 { + return errInvalidQOSLevel + } + + // If anything protobuf-related is specified, it's being used + if opts.ReadProtobufRootMessage != "" || len(opts.ReadProtobufDirs) != 0 { + if err := cli.ValidateProtobufOptions( + opts.ReadProtobufDirs, + opts.ReadProtobufRootMessage, + ); err != nil { + return fmt.Errorf("unable to validate protobuf option(s): %s", err) + } + } + + return nil +} + +// Relay reads messages from MQTT and sends them to RelayCh which is then read by relay.Run() +func (r *Relayer) Relay() error { + r.log.Infof("Relaying MQTT messages from topic '%s' -> '%s'", + r.Options.MQTT.Topic, r.Options.RelayGRPCAddress) + + r.log.Infof("HTTP server listening on '%s'", r.Options.RelayHTTPListenAddress) + + defer r.Client.Disconnect(0) + + r.Client.Subscribe(r.Options.MQTT.Topic, byte(r.Options.MQTT.QoSLevel), func(client mqtt.Client, msg mqtt.Message) { + + stats.Incr("mqtt-relay-consumer", 1) + + // Generate relay message + r.RelayCh <- &types.RelayMessage{ + Value: msg, + } + + r.log.Debugf("Successfully relayed message '%d' from topic '%s'", msg.MessageID(), msg.Topic()) + + }) + + for { + select { + case <-r.Context.Done(): + return nil + } + } + + return nil } diff --git a/backends/mqtt/types/types.go b/backends/mqtt/types/types.go new file mode 100644 index 00000000..af34ce3a --- /dev/null +++ b/backends/mqtt/types/types.go @@ -0,0 +1,13 @@ +package types + +import mqtt "github.com/eclipse/paho.mqtt.golang" + +// RelayMessage encapsulates a kafka message that is read by relay.Run() +type RelayMessage struct { + Value mqtt.Message + Options *RelayMessageOptions +} + +// RelayMessageOptions contains any additional options necessary for processing of Kafka messages by the relayer +type RelayMessageOptions struct { +} diff --git a/cli/cli.go b/cli/cli.go index f410b8e2..76890f10 100644 --- a/cli/cli.go +++ b/cli/cli.go @@ -138,11 +138,13 @@ func Handle(cliArgs []string) (string, *Options, error) { HandleCDCPostgresFlags(readCmd, writeCmd, relayCmd, opts) case "cdc-mongo": HandleCDCMongoFlags(readCmd, writeCmd, relayCmd, opts) + case "mqtt": + HandleMQTTFlags(readCmd, writeCmd, relayCmd, opts) default: HandleKafkaFlags(readCmd, writeCmd, relayCmd, opts) HandleRabbitFlags(readCmd, writeCmd, relayCmd, opts) HandleGCPPubSubFlags(readCmd, writeCmd, relayCmd, opts) - HandleMQTTFlags(readCmd, writeCmd, opts) + HandleMQTTFlags(readCmd, writeCmd, relayCmd, opts) HandleAWSSQSFlags(readCmd, writeCmd, relayCmd, opts) HandleActiveMqFlags(readCmd, writeCmd, opts) HandleAWSSNSFlags(readCmd, writeCmd, relayCmd, opts) @@ -263,7 +265,8 @@ func HandleGlobalFlags(cmd *kingpin.CmdClause, opts *Options) { func HandleRelayFlags(relayCmd *kingpin.CmdClause, opts *Options) { relayCmd.Flag("type", "Type of collector to use. Ex: rabbit, kafka, aws-sqs, azure, gcp-pubsub, redis-pubsub, redis-streams"). Envar("PLUMBER_RELAY_TYPE"). - EnumVar(&opts.RelayType, "aws-sqs", "rabbit", "kafka", "azure", "gcp-pubsub", "redis-pubsub", "redis-streams", "cdc-postgres", "cdc-mongo") + EnumVar(&opts.RelayType, "aws-sqs", "rabbit", "kafka", "azure", "gcp-pubsub", "redis-pubsub", + "redis-streams", "cdc-postgres", "cdc-mongo", "mqtt") relayCmd.Flag("token", "Collection token to use when sending data to Batch"). Required(). diff --git a/cli/mqtt.go b/cli/mqtt.go index 69570c38..d49e13d8 100644 --- a/cli/mqtt.go +++ b/cli/mqtt.go @@ -2,6 +2,7 @@ package cli import ( "fmt" + "os" "time" "github.com/google/uuid" @@ -34,7 +35,7 @@ type MQTTOptions struct { WriteTimeout time.Duration } -func HandleMQTTFlags(readCmd, writeCmd *kingpin.CmdClause, opts *Options) { +func HandleMQTTFlags(readCmd, writeCmd, relayCmd *kingpin.CmdClause, opts *Options) { rc := readCmd.Command("mqtt", "MQTT message system") addSharedMQTTFlags(rc, opts) @@ -44,24 +45,65 @@ func HandleMQTTFlags(readCmd, writeCmd *kingpin.CmdClause, opts *Options) { addSharedMQTTFlags(wc, opts) addWriteMQTTFlags(wc, opts) + + // If PLUMBER_RELAY_TYPE is set, use env vars, otherwise use CLI flags + relayType := os.Getenv("PLUMBER_RELAY_TYPE") + + var rec *kingpin.CmdClause + + if relayType != "" { + rec = relayCmd + } else { + rec = relayCmd.Command("mqtt", "MQTT message system") + } + + addSharedMQTTFlags(rec, opts) + addReadMQTTFlags(rec, opts) } func addSharedMQTTFlags(cmd *kingpin.CmdClause, opts *Options) { clientId := fmt.Sprintf("%s-%s", MQTTDefaultClientId, uuid.New().String()[0:3]) - cmd.Flag("address", "Destination host address").Default("tcp://localhost:1883").StringVar(&opts.MQTT.Address) - cmd.Flag("topic", "Topic to read message(s) from").Required().StringVar(&opts.MQTT.Topic) - cmd.Flag("timeout", "Connect timeout").Default(MQTTDefaultConnectTimeout). + cmd.Flag("address", "Destination host address"). + Envar("PLUMBER_RELAY_MQTT_ADDRESS"). + Default("tcp://localhost:1883"). + StringVar(&opts.MQTT.Address) + + cmd.Flag("topic", "Topic to read message(s) from"). + Envar("PLUMBER_RELAY_MQTT_TOPIC"). + Required(). + StringVar(&opts.MQTT.Topic) + + cmd.Flag("timeout", "Connect timeout"). + Envar("PLUMBER_RELAY_MQTT_CONNECT_TIMEOUT"). + Default(MQTTDefaultConnectTimeout). DurationVar(&opts.MQTT.Timeout) + cmd.Flag("client-id", "Client id presented to MQTT broker"). - Default(clientId).StringVar(&opts.MQTT.ClientID) - cmd.Flag("qos", "QoS level to use for pub/sub (0, 1, 2)").Default("0").IntVar(&opts.MQTT.QoSLevel) - cmd.Flag("tls-ca-file", "CA file (only needed if addr is ssl://").ExistingFileVar(&opts.MQTT.TLSCAFile) + Envar("PLUMBER_RELAY_MQTT_CLIENT_ID"). + Default(clientId). + StringVar(&opts.MQTT.ClientID) + + cmd.Flag("qos", "QoS level to use for pub/sub (0, 1, 2)"). + Envar("PLUMBER_RELAY_MQTT_QOS"). + Default("0"). + IntVar(&opts.MQTT.QoSLevel) + + cmd.Flag("tls-ca-file", "CA file (only needed if addr is ssl://"). + Envar("PLUMBER_RELAY_MQTT_TLS_CA_FILE"). + ExistingFileVar(&opts.MQTT.TLSCAFile) + cmd.Flag("tls-client-cert-file", "Client cert file (only needed if addr is ssl://"). + Envar("PLUMBER_RELAY_MQTT_TLS_CERT_FILE"). ExistingFileVar(&opts.MQTT.TLSClientCertFile) + cmd.Flag("tls-client-key-file", "Client key file (only needed if addr is ssl://"). + Envar("PLUMBER_RELAY_MQTT_TLS_KEY_FILE"). ExistingFileVar(&opts.MQTT.TLSClientKeyFile) - cmd.Flag("insecure-tls", "Whether to verify server certificate").Default("false"). + + cmd.Flag("insecure-tls", "Whether to verify server certificate"). + Envar("PLUMBER_RELAY_MQTT_SKIP_VERIFY_TLS"). + Default("false"). BoolVar(&opts.MQTT.InsecureTLS) } diff --git a/go.mod b/go.mod index 9089ea80..1a562c19 100644 --- a/go.mod +++ b/go.mod @@ -10,7 +10,7 @@ require ( github.com/aws/aws-sdk-go v1.34.28 github.com/batchcorp/pgoutput v0.3.2 github.com/batchcorp/rabbit v0.1.9 - github.com/batchcorp/schemas v0.2.128 + github.com/batchcorp/schemas v0.2.154 github.com/dustin/go-humanize v1.0.0 // indirect github.com/eclipse/paho.mqtt.golang v1.2.0 github.com/go-redis/redis/v8 v8.4.8 diff --git a/go.sum b/go.sum index a12683d6..ca388787 100644 --- a/go.sum +++ b/go.sum @@ -127,6 +127,8 @@ github.com/batchcorp/schemas v0.2.125 h1:EVfANxZsYAOjHo79sF5fIA7x8DPsc9PsQCAC7ja github.com/batchcorp/schemas v0.2.125/go.mod h1:R6rjH3b0egODh995q5qwGAfQ5fssAPeDf82gTGZS6d4= github.com/batchcorp/schemas v0.2.128 h1:EjhxReDCkj3QvkVDiSHHbGOjUXSJ2jrSpZ3QG0Fs+us= github.com/batchcorp/schemas v0.2.128/go.mod h1:R6rjH3b0egODh995q5qwGAfQ5fssAPeDf82gTGZS6d4= +github.com/batchcorp/schemas v0.2.154 h1:IDjvtZTBGgk7KrdysR/Le4iErT51hHunMOipS8ycrGI= +github.com/batchcorp/schemas v0.2.154/go.mod h1:R6rjH3b0egODh995q5qwGAfQ5fssAPeDf82gTGZS6d4= github.com/batchcorp/schemas/util/publish v0.0.0-20200622021112-903044310a85/go.mod h1:zD8BqPOqqGw2wWhGrJx8CguDKKuOPGo1TXOuz5b4OR4= github.com/beefsack/go-rate v0.0.0-20180408011153-efa7637bb9b6/go.mod h1:6YNgTHLutezwnBvyneBbwvB8C82y3dcoOj5EQJIdGXA= github.com/beorn7/perks v0.0.0-20180321164747-3a771d992973/go.mod h1:Dwedo/Wpr24TaqPxmxbtue+5NUziq4I4S80YR8gNf3Q= diff --git a/relay/mqtt.go b/relay/mqtt.go new file mode 100644 index 00000000..848abf88 --- /dev/null +++ b/relay/mqtt.go @@ -0,0 +1,71 @@ +package relay + +import ( + "context" + "fmt" + "time" + + "github.com/batchcorp/plumber/backends/mqtt/types" + "github.com/batchcorp/schemas/build/go/events/records" + "github.com/batchcorp/schemas/build/go/services" + "google.golang.org/grpc" +) + +// handleMQTT sends a MQTT relay message to the GRPC server +func (r *Relay) handleMQTT(ctx context.Context, conn *grpc.ClientConn, messages []interface{}) error { + sinkRecords, err := r.convertMessagesToMQTTRecords(messages) + if err != nil { + return fmt.Errorf("unable to convert messages to MQTT sink records: %s", err) + } + + client := services.NewGRPCCollectorClient(conn) + + return r.CallWithRetry(ctx, "AddMQTTRecord", func(ctx context.Context) error { + _, err := client.AddMQTTRecord(ctx, &services.MQTTRecordRequest{ + Records: sinkRecords, + }, grpc.MaxCallRecvMsgSize(MaxGRPCMessageSize)) + return err + }) +} + +// validateMQTTMessage ensures all necessary values are present for a MQTT relay message +func (r *Relay) validateMQTTMessage(msg *types.RelayMessage) error { + if msg == nil { + return errMissingMessage + } + + if msg.Value == nil { + return errMissingMessageValue + } + + return nil +} + +// convertMessagesToMQTTRecords creates a records.MQTTRecord from a MQTT.Message which can then +// be sent to the GRPC server +func (r *Relay) convertMessagesToMQTTRecords(messages []interface{}) ([]*records.MQTTRecord, error) { + sinkRecords := make([]*records.MQTTRecord, 0) + + for i, v := range messages { + relayMessage, ok := v.(*types.RelayMessage) + if !ok { + return nil, fmt.Errorf("unable to type assert incoming message as RelayMessage (index: %d)", i) + } + + if err := r.validateMQTTMessage(relayMessage); err != nil { + return nil, fmt.Errorf("unable to validate MQTT relay message (index: %d): %s", i, err) + } + + sinkRecords = append(sinkRecords, &records.MQTTRecord{ + Id: uint32(relayMessage.Value.MessageID()), + Topic: relayMessage.Value.Topic(), + Duplicate: relayMessage.Value.Duplicate(), + Retained: relayMessage.Value.Retained(), + Qos: uint32(relayMessage.Value.Qos()), + Value: relayMessage.Value.Payload(), + Timestamp: time.Now().UTC().UnixNano(), + }) + } + + return sinkRecords, nil +} diff --git a/relay/relay.go b/relay/relay.go index 1e593f51..e8e73b4b 100644 --- a/relay/relay.go +++ b/relay/relay.go @@ -20,6 +20,7 @@ import ( postgresTypes "github.com/batchcorp/plumber/backends/cdc-postgres/types" gcpTypes "github.com/batchcorp/plumber/backends/gcp-pubsub/types" kafkaTypes "github.com/batchcorp/plumber/backends/kafka/types" + mqttTypes "github.com/batchcorp/plumber/backends/mqtt/types" rabbitTypes "github.com/batchcorp/plumber/backends/rabbitmq/types" redisTypes "github.com/batchcorp/plumber/backends/rpubsub/types" rstreamsTypes "github.com/batchcorp/plumber/backends/rstreams/types" @@ -250,6 +251,9 @@ func (r *Relay) flush(ctx context.Context, conn *grpc.ClientConn, messages ...in case *postgresTypes.RelayMessage: r.log.Debugf("flushing %d cdc-postgres message(s)", len(messages)) err = r.handleCdcPostgres(ctx, conn, messages) + case *mqttTypes.RelayMessage: + r.log.Debugf("flushing %d mqtt message(s)", len(messages)) + err = r.handleMQTT(ctx, conn, messages) default: r.log.WithField("type", v).Error("received unknown message type - skipping") return diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/apitoken.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/apitoken.pb.go new file mode 100644 index 00000000..e41fb36b --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/apitoken.pb.go @@ -0,0 +1,90 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: apitoken.proto + +package events + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +// ApiToken message contains info for an API token used to authenticate plumber dynamic destinations +type APIToken struct { + // Internal database ID of the token + Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` + // The actual token used for authentication + Token string `protobuf:"bytes,2,opt,name=token,proto3" json:"token,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *APIToken) Reset() { *m = APIToken{} } +func (m *APIToken) String() string { return proto.CompactTextString(m) } +func (*APIToken) ProtoMessage() {} +func (*APIToken) Descriptor() ([]byte, []int) { + return fileDescriptor_2671613489b1fb3b, []int{0} +} + +func (m *APIToken) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_APIToken.Unmarshal(m, b) +} +func (m *APIToken) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_APIToken.Marshal(b, m, deterministic) +} +func (m *APIToken) XXX_Merge(src proto.Message) { + xxx_messageInfo_APIToken.Merge(m, src) +} +func (m *APIToken) XXX_Size() int { + return xxx_messageInfo_APIToken.Size(m) +} +func (m *APIToken) XXX_DiscardUnknown() { + xxx_messageInfo_APIToken.DiscardUnknown(m) +} + +var xxx_messageInfo_APIToken proto.InternalMessageInfo + +func (m *APIToken) GetId() string { + if m != nil { + return m.Id + } + return "" +} + +func (m *APIToken) GetToken() string { + if m != nil { + return m.Token + } + return "" +} + +func init() { + proto.RegisterType((*APIToken)(nil), "events.APIToken") +} + +func init() { proto.RegisterFile("apitoken.proto", fileDescriptor_2671613489b1fb3b) } + +var fileDescriptor_2671613489b1fb3b = []byte{ + // 135 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xe2, 0xe2, 0x4b, 0x2c, 0xc8, 0x2c, + 0xc9, 0xcf, 0x4e, 0xcd, 0xd3, 0x2b, 0x28, 0xca, 0x2f, 0xc9, 0x17, 0x62, 0x4b, 0x2d, 0x4b, 0xcd, + 0x2b, 0x29, 0x56, 0x32, 0xe0, 0xe2, 0x70, 0x0c, 0xf0, 0x0c, 0x01, 0xc9, 0x08, 0xf1, 0x71, 0x31, + 0x65, 0xa6, 0x48, 0x30, 0x2a, 0x30, 0x6a, 0x70, 0x06, 0x31, 0x65, 0xa6, 0x08, 0x89, 0x70, 0xb1, + 0x82, 0xb5, 0x48, 0x30, 0x81, 0x85, 0x20, 0x1c, 0x27, 0xbd, 0x28, 0x9d, 0xf4, 0xcc, 0x92, 0x8c, + 0xd2, 0x24, 0xbd, 0xe4, 0xfc, 0x5c, 0xfd, 0xa4, 0xc4, 0x92, 0xe4, 0x8c, 0xe4, 0xfc, 0xa2, 0x02, + 0xfd, 0xe2, 0xe4, 0x8c, 0xd4, 0xdc, 0xc4, 0x62, 0xfd, 0xa4, 0xd2, 0xcc, 0x9c, 0x14, 0xfd, 0xf4, + 0x7c, 0x7d, 0x88, 0x0d, 0x49, 0x6c, 0x60, 0x0b, 0x8d, 0x01, 0x01, 0x00, 0x00, 0xff, 0xff, 0x13, + 0x5f, 0x1a, 0x91, 0x82, 0x00, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/destination.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/destination.pb.go index c12f178a..14929663 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/destination.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/destination.pb.go @@ -24,11 +24,14 @@ const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package type Destination_Type int32 const ( - Destination_UNSET Destination_Type = 0 - Destination_HTTP Destination_Type = 1 - Destination_AMQP Destination_Type = 2 - Destination_SQS Destination_Type = 3 - Destination_KAFKA Destination_Type = 4 + Destination_UNSET Destination_Type = 0 + Destination_HTTP Destination_Type = 1 + Destination_AMQP Destination_Type = 2 + Destination_SQS Destination_Type = 3 + Destination_KAFKA Destination_Type = 4 + Destination_REDIS_PUBSUB Destination_Type = 5 + Destination_REDIS_STREAMS Destination_Type = 6 + Destination_DYNAMIC Destination_Type = 7 ) var Destination_Type_name = map[int32]string{ @@ -37,14 +40,20 @@ var Destination_Type_name = map[int32]string{ 2: "AMQP", 3: "SQS", 4: "KAFKA", + 5: "REDIS_PUBSUB", + 6: "REDIS_STREAMS", + 7: "DYNAMIC", } var Destination_Type_value = map[string]int32{ - "UNSET": 0, - "HTTP": 1, - "AMQP": 2, - "SQS": 3, - "KAFKA": 4, + "UNSET": 0, + "HTTP": 1, + "AMQP": 2, + "SQS": 3, + "KAFKA": 4, + "REDIS_PUBSUB": 5, + "REDIS_STREAMS": 6, + "DYNAMIC": 7, } func (x Destination_Type) String() string { @@ -65,6 +74,9 @@ type Destination struct { // *Destination_Amqp // *Destination_Sqs // *Destination_Kafka + // *Destination_RedisPubsub + // *Destination_RedisStreams + // *Destination_Dynamic Dest isDestination_Dest `protobuf_oneof:"dest"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -144,6 +156,18 @@ type Destination_Kafka struct { Kafka *destinations.Kafka `protobuf:"bytes,103,opt,name=kafka,proto3,oneof"` } +type Destination_RedisPubsub struct { + RedisPubsub *destinations.RedisPubsub `protobuf:"bytes,104,opt,name=redis_pubsub,json=redisPubsub,proto3,oneof"` +} + +type Destination_RedisStreams struct { + RedisStreams *destinations.RedisStreams `protobuf:"bytes,105,opt,name=redis_streams,json=redisStreams,proto3,oneof"` +} + +type Destination_Dynamic struct { + Dynamic *destinations.Dynamic `protobuf:"bytes,106,opt,name=dynamic,proto3,oneof"` +} + func (*Destination_Http) isDestination_Dest() {} func (*Destination_Amqp) isDestination_Dest() {} @@ -152,6 +176,12 @@ func (*Destination_Sqs) isDestination_Dest() {} func (*Destination_Kafka) isDestination_Dest() {} +func (*Destination_RedisPubsub) isDestination_Dest() {} + +func (*Destination_RedisStreams) isDestination_Dest() {} + +func (*Destination_Dynamic) isDestination_Dest() {} + func (m *Destination) GetDest() isDestination_Dest { if m != nil { return m.Dest @@ -187,6 +217,27 @@ func (m *Destination) GetKafka() *destinations.Kafka { return nil } +func (m *Destination) GetRedisPubsub() *destinations.RedisPubsub { + if x, ok := m.GetDest().(*Destination_RedisPubsub); ok { + return x.RedisPubsub + } + return nil +} + +func (m *Destination) GetRedisStreams() *destinations.RedisStreams { + if x, ok := m.GetDest().(*Destination_RedisStreams); ok { + return x.RedisStreams + } + return nil +} + +func (m *Destination) GetDynamic() *destinations.Dynamic { + if x, ok := m.GetDest().(*Destination_Dynamic); ok { + return x.Dynamic + } + return nil +} + // XXX_OneofWrappers is for the internal use of the proto package. func (*Destination) XXX_OneofWrappers() []interface{} { return []interface{}{ @@ -194,6 +245,9 @@ func (*Destination) XXX_OneofWrappers() []interface{} { (*Destination_Amqp)(nil), (*Destination_Sqs)(nil), (*Destination_Kafka)(nil), + (*Destination_RedisPubsub)(nil), + (*Destination_RedisStreams)(nil), + (*Destination_Dynamic)(nil), } } @@ -205,27 +259,36 @@ func init() { func init() { proto.RegisterFile("destination.proto", fileDescriptor_a55fe39993114776) } var fileDescriptor_a55fe39993114776 = []byte{ - // 351 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x91, 0xdf, 0x4b, 0xeb, 0x30, - 0x14, 0xc7, 0xfb, 0x6b, 0xbb, 0x77, 0x67, 0x30, 0xba, 0xdc, 0xcb, 0xbd, 0x41, 0x10, 0xc6, 0x40, - 0x28, 0x38, 0x52, 0x98, 0x4f, 0x3e, 0x6e, 0xa8, 0x14, 0x86, 0xe2, 0xda, 0xfa, 0xe2, 0x8b, 0xa4, - 0x6d, 0xb6, 0x96, 0xb9, 0xa6, 0x5b, 0x32, 0xa1, 0x7f, 0xb3, 0xff, 0x84, 0x24, 0x9d, 0xb8, 0x8a, - 0x6f, 0xc9, 0xf9, 0x7c, 0x72, 0xf8, 0x9e, 0x13, 0x18, 0x66, 0x4c, 0xc8, 0xa2, 0xa4, 0xb2, 0xe0, - 0x25, 0xa9, 0xf6, 0x5c, 0x72, 0xd4, 0x65, 0x6f, 0xac, 0x94, 0xe2, 0xec, 0xff, 0x09, 0x12, 0x3e, - 0xdd, 0xee, 0xaa, 0x46, 0xf8, 0x06, 0x72, 0x29, 0x3f, 0xc1, 0xbf, 0x16, 0x10, 0x3b, 0x71, 0xac, - 0xe3, 0x56, 0x7d, 0x43, 0x57, 0x1b, 0xda, 0x90, 0xf1, 0xbb, 0x05, 0xfd, 0x9b, 0x2f, 0x88, 0x06, - 0x60, 0x15, 0x19, 0x36, 0x47, 0xa6, 0xd7, 0x0b, 0xad, 0x22, 0x43, 0x13, 0x70, 0x64, 0x5d, 0x31, - 0x6c, 0x8d, 0x4c, 0x6f, 0x30, 0xc5, 0xa4, 0x89, 0x46, 0x4e, 0x9e, 0x90, 0xb8, 0xae, 0x58, 0xa8, - 0x2d, 0xf4, 0x17, 0x3a, 0x25, 0x97, 0x4c, 0x60, 0x5b, 0x37, 0x68, 0x2e, 0xe8, 0x1c, 0x20, 0xdd, - 0x33, 0x2a, 0x59, 0xf6, 0x92, 0xd4, 0xd8, 0xd1, 0xa8, 0x77, 0xac, 0xcc, 0x6b, 0xe4, 0x81, 0xa3, - 0x46, 0xc0, 0xd9, 0xc8, 0xf4, 0xfa, 0x53, 0x44, 0x4e, 0xb3, 0x92, 0x20, 0x8e, 0x1f, 0x03, 0x23, - 0xd4, 0x86, 0x32, 0xd5, 0x16, 0x30, 0xfb, 0xc9, 0x9c, 0xdd, 0x2f, 0xb5, 0xa9, 0x0c, 0x74, 0x01, - 0xb6, 0xd8, 0x09, 0xbc, 0xd2, 0xe2, 0xb0, 0x2d, 0x46, 0xcb, 0x28, 0x30, 0x42, 0xc5, 0xd1, 0x25, - 0x74, 0xf4, 0x32, 0xf0, 0x5a, 0x8b, 0x7f, 0xda, 0xe2, 0x42, 0xa1, 0xc0, 0x08, 0x1b, 0x67, 0x7c, - 0x0d, 0x8e, 0x1a, 0x15, 0xf5, 0xa0, 0xf3, 0xf4, 0x10, 0xdd, 0xc6, 0xae, 0x81, 0x7e, 0x83, 0xa3, - 0x02, 0xba, 0xa6, 0x3a, 0xa9, 0x00, 0xae, 0x85, 0x7e, 0x81, 0x1d, 0x2d, 0x23, 0xd7, 0x56, 0xde, - 0x62, 0x76, 0xb7, 0x98, 0xb9, 0xce, 0xbc, 0x0b, 0x8e, 0xea, 0x3c, 0x27, 0xcf, 0x93, 0x75, 0x21, - 0xf3, 0x43, 0x42, 0x52, 0xbe, 0xf5, 0x13, 0x2a, 0xd3, 0x3c, 0xe5, 0xfb, 0xca, 0x17, 0x69, 0xce, - 0xb6, 0x54, 0xf8, 0xc9, 0xa1, 0x78, 0xcd, 0xfc, 0x35, 0xf7, 0x9b, 0x35, 0x27, 0x5d, 0xfd, 0x49, - 0x57, 0x1f, 0x01, 0x00, 0x00, 0xff, 0xff, 0x54, 0x00, 0x72, 0xab, 0x25, 0x02, 0x00, 0x00, + // 490 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x92, 0x5d, 0x8b, 0xda, 0x4c, + 0x14, 0xc7, 0xa3, 0x46, 0x7d, 0x3c, 0xee, 0x2e, 0x71, 0x9e, 0xbe, 0x4c, 0x85, 0x52, 0x59, 0x28, + 0x08, 0xdd, 0x26, 0x74, 0x7b, 0x5f, 0x88, 0xd5, 0x92, 0x45, 0x5c, 0x74, 0x46, 0x2f, 0xda, 0x1b, + 0xc9, 0xcb, 0xac, 0xa6, 0xd6, 0x24, 0x66, 0xc6, 0x42, 0x3e, 0x67, 0xbf, 0x50, 0x99, 0x99, 0xc8, + 0x9a, 0xe2, 0x9d, 0x73, 0x7e, 0xbf, 0x73, 0x9c, 0xfc, 0xcf, 0x40, 0x2f, 0x62, 0x5c, 0xc4, 0x89, + 0x2f, 0xe2, 0x34, 0xb1, 0xb3, 0x3c, 0x15, 0x29, 0x6a, 0xb1, 0xdf, 0x2c, 0x11, 0xbc, 0xff, 0xfa, + 0x0c, 0x71, 0xc7, 0xdf, 0x1f, 0x32, 0x2d, 0xfc, 0x03, 0xb6, 0x42, 0x9c, 0xc0, 0xab, 0x0a, 0xe0, + 0x07, 0x5e, 0xd6, 0x71, 0xa5, 0xbe, 0xf3, 0x9f, 0x76, 0x7e, 0x49, 0xde, 0x55, 0x48, 0xce, 0xa2, + 0x98, 0x7f, 0xcc, 0x8e, 0x01, 0x3f, 0x06, 0xa5, 0x30, 0xb8, 0x20, 0x70, 0x91, 0x33, 0x7f, 0x7f, + 0x1a, 0xde, 0xaf, 0x18, 0x51, 0x91, 0xf8, 0xfb, 0x38, 0xd4, 0xec, 0xf6, 0x8f, 0x09, 0xdd, 0xf1, + 0x33, 0x46, 0x37, 0x50, 0x8f, 0x23, 0x5c, 0x1b, 0xd4, 0x86, 0x1d, 0x52, 0x8f, 0x23, 0x74, 0x07, + 0xa6, 0x28, 0x32, 0x86, 0xeb, 0x83, 0xda, 0xf0, 0xe6, 0x1e, 0xdb, 0xfa, 0xcb, 0xed, 0xb3, 0x16, + 0x7b, 0x59, 0x64, 0x8c, 0x28, 0x0b, 0xbd, 0x80, 0x66, 0x92, 0x0a, 0xc6, 0x71, 0x43, 0x0d, 0xd0, + 0x07, 0xf4, 0x16, 0x20, 0xcc, 0x99, 0x2f, 0x58, 0xb4, 0x0e, 0x0a, 0x6c, 0x2a, 0xd4, 0x29, 0x2b, + 0xa3, 0x02, 0x0d, 0xc1, 0x94, 0x09, 0xe1, 0x68, 0x50, 0x1b, 0x76, 0xef, 0x91, 0x7d, 0x7e, 0x5b, + 0xdb, 0x5b, 0x2e, 0xe7, 0x9e, 0x41, 0x94, 0x21, 0x4d, 0x19, 0x32, 0x66, 0x97, 0x4c, 0x77, 0xb6, + 0x50, 0xa6, 0x34, 0xd0, 0x7b, 0x68, 0xf0, 0x03, 0xc7, 0x4f, 0x4a, 0xec, 0x55, 0x45, 0xba, 0xa0, + 0x9e, 0x41, 0x24, 0x47, 0x1f, 0xa0, 0xa9, 0xb2, 0xc6, 0x1b, 0x25, 0xfe, 0x5f, 0x15, 0xa7, 0x12, + 0x79, 0x06, 0xd1, 0x0e, 0xfa, 0x02, 0x57, 0x2a, 0xdd, 0xb5, 0x8e, 0x1f, 0x6f, 0x55, 0xcf, 0x9b, + 0x6a, 0x0f, 0x91, 0xc6, 0x5c, 0x09, 0x9e, 0x41, 0xba, 0xf9, 0xf3, 0x11, 0xb9, 0x70, 0xad, 0xfb, + 0xcb, 0xed, 0xe0, 0x58, 0x0d, 0xe8, 0x5f, 0x18, 0x40, 0xb5, 0xe1, 0x19, 0x44, 0xff, 0x65, 0x79, + 0x46, 0x9f, 0xa0, 0x5d, 0xae, 0x0f, 0xff, 0x54, 0xcd, 0x2f, 0xab, 0xcd, 0x63, 0x0d, 0x3d, 0x83, + 0x9c, 0xbc, 0xdb, 0x1d, 0x98, 0x72, 0x41, 0xa8, 0x03, 0xcd, 0xd5, 0x23, 0x9d, 0x2c, 0x2d, 0x03, + 0xfd, 0x07, 0xa6, 0x8c, 0xd5, 0xaa, 0xc9, 0x5f, 0x32, 0x36, 0xab, 0x8e, 0xda, 0xd0, 0xa0, 0x0b, + 0x6a, 0x35, 0xa4, 0x37, 0x75, 0xbf, 0x4d, 0x5d, 0xcb, 0x44, 0x16, 0x5c, 0x91, 0xc9, 0xf8, 0x81, + 0xae, 0xe7, 0xab, 0x11, 0x5d, 0x8d, 0xac, 0x26, 0xea, 0xc1, 0xb5, 0xae, 0xd0, 0x25, 0x99, 0xb8, + 0x33, 0x6a, 0xb5, 0x50, 0x17, 0xda, 0xe3, 0xef, 0x8f, 0xee, 0xec, 0xe1, 0xab, 0xd5, 0x1e, 0xb5, + 0xc0, 0x94, 0xf7, 0x19, 0xd9, 0x3f, 0xee, 0x36, 0xb1, 0xd8, 0x1e, 0x03, 0x3b, 0x4c, 0xf7, 0x4e, + 0xe0, 0x8b, 0x70, 0x1b, 0xa6, 0x79, 0xe6, 0xf0, 0x70, 0xcb, 0xf6, 0x3e, 0x77, 0x82, 0x63, 0xfc, + 0x2b, 0x72, 0x36, 0xa9, 0xa3, 0x9f, 0x53, 0xd0, 0x52, 0x8f, 0xf1, 0xf3, 0xdf, 0x00, 0x00, 0x00, + 0xff, 0xff, 0xb3, 0x57, 0x81, 0xce, 0x6c, 0x03, 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/destinations/dynamic.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/dynamic.pb.go new file mode 100644 index 00000000..792dbe61 --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/dynamic.pb.go @@ -0,0 +1,103 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/destinations/dynamic.proto + +package destinations + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type Dynamic struct { + // Hash of message teamID, message bus and client IP + // Used to track connections on dproxy instances + PlumberClientId string `protobuf:"bytes,1,opt,name=plumber_client_id,json=plumberClientId,proto3" json:"plumber_client_id,omitempty"` + // USed for client display in the frontend + SourceIp string `protobuf:"bytes,2,opt,name=source_ip,json=sourceIp,proto3" json:"source_ip,omitempty"` + // Used for client display in the frontend + MessageBus string `protobuf:"bytes,3,opt,name=message_bus,json=messageBus,proto3" json:"message_bus,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *Dynamic) Reset() { *m = Dynamic{} } +func (m *Dynamic) String() string { return proto.CompactTextString(m) } +func (*Dynamic) ProtoMessage() {} +func (*Dynamic) Descriptor() ([]byte, []int) { + return fileDescriptor_0d8fc90d2870b5a2, []int{0} +} + +func (m *Dynamic) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_Dynamic.Unmarshal(m, b) +} +func (m *Dynamic) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_Dynamic.Marshal(b, m, deterministic) +} +func (m *Dynamic) XXX_Merge(src proto.Message) { + xxx_messageInfo_Dynamic.Merge(m, src) +} +func (m *Dynamic) XXX_Size() int { + return xxx_messageInfo_Dynamic.Size(m) +} +func (m *Dynamic) XXX_DiscardUnknown() { + xxx_messageInfo_Dynamic.DiscardUnknown(m) +} + +var xxx_messageInfo_Dynamic proto.InternalMessageInfo + +func (m *Dynamic) GetPlumberClientId() string { + if m != nil { + return m.PlumberClientId + } + return "" +} + +func (m *Dynamic) GetSourceIp() string { + if m != nil { + return m.SourceIp + } + return "" +} + +func (m *Dynamic) GetMessageBus() string { + if m != nil { + return m.MessageBus + } + return "" +} + +func init() { + proto.RegisterType((*Dynamic)(nil), "destinations.Dynamic") +} + +func init() { proto.RegisterFile("events/destinations/dynamic.proto", fileDescriptor_0d8fc90d2870b5a2) } + +var fileDescriptor_0d8fc90d2870b5a2 = []byte{ + // 196 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0xcf, 0x3b, 0x6b, 0xc3, 0x30, + 0x14, 0xc5, 0x71, 0xdc, 0x42, 0x5b, 0xab, 0x85, 0x52, 0x4d, 0x86, 0x0e, 0x7d, 0x4c, 0xa5, 0x83, + 0x35, 0x74, 0x2a, 0xdd, 0xdc, 0x2c, 0x5e, 0x33, 0x66, 0x11, 0x7a, 0x5c, 0xec, 0x0b, 0xd6, 0x03, + 0x5d, 0x29, 0x90, 0x6f, 0x1f, 0x90, 0x3d, 0x64, 0xc8, 0xfa, 0xff, 0x9d, 0xe5, 0xb0, 0x0f, 0x38, + 0x82, 0xcf, 0x24, 0x2c, 0x50, 0x46, 0xaf, 0x32, 0x06, 0x4f, 0xc2, 0x9e, 0xbc, 0x72, 0x68, 0xfa, + 0x98, 0x42, 0x0e, 0xfc, 0xe9, 0xd2, 0x3e, 0x89, 0xdd, 0xef, 0x56, 0xe6, 0xdf, 0xec, 0x25, 0x2e, + 0xc5, 0x69, 0x48, 0xd2, 0x2c, 0x08, 0x3e, 0x4b, 0xb4, 0x5d, 0xf3, 0xde, 0x7c, 0xb5, 0xfb, 0xe7, + 0x0d, 0xfe, 0x6b, 0x1f, 0x2d, 0x7f, 0x65, 0x2d, 0x85, 0x92, 0x0c, 0x48, 0x8c, 0xdd, 0x4d, 0xdd, + 0x3c, 0xac, 0x61, 0x8c, 0xfc, 0x8d, 0x3d, 0x3a, 0x20, 0x52, 0x13, 0x48, 0x5d, 0xa8, 0xbb, 0xad, + 0xcc, 0xb6, 0x34, 0x14, 0x1a, 0xfe, 0x0e, 0xbf, 0x13, 0xe6, 0xb9, 0xe8, 0xde, 0x04, 0x27, 0xb4, + 0xca, 0x66, 0x36, 0x21, 0x45, 0x41, 0x66, 0x06, 0xa7, 0x48, 0xe8, 0x82, 0x8b, 0x15, 0x53, 0x10, + 0x57, 0xde, 0xe8, 0xbb, 0x7a, 0xe3, 0xe7, 0x1c, 0x00, 0x00, 0xff, 0xff, 0xc2, 0xdb, 0x85, 0x6a, + 0xeb, 0x00, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-pubsub.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-pubsub.pb.go new file mode 100644 index 00000000..fe7aaacc --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-pubsub.pb.go @@ -0,0 +1,117 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/destinations/redis-pubsub.proto + +package destinations + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type RedisPubsub struct { + Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"` + Database int32 `protobuf:"varint,2,opt,name=database,proto3" json:"database,omitempty"` + Username string `protobuf:"bytes,3,opt,name=username,proto3" json:"username,omitempty"` + Password string `protobuf:"bytes,4,opt,name=password,proto3" json:"password,omitempty"` + Channels []string `protobuf:"bytes,5,rep,name=channels,proto3" json:"channels,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *RedisPubsub) Reset() { *m = RedisPubsub{} } +func (m *RedisPubsub) String() string { return proto.CompactTextString(m) } +func (*RedisPubsub) ProtoMessage() {} +func (*RedisPubsub) Descriptor() ([]byte, []int) { + return fileDescriptor_35320f6d09c25866, []int{0} +} + +func (m *RedisPubsub) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_RedisPubsub.Unmarshal(m, b) +} +func (m *RedisPubsub) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_RedisPubsub.Marshal(b, m, deterministic) +} +func (m *RedisPubsub) XXX_Merge(src proto.Message) { + xxx_messageInfo_RedisPubsub.Merge(m, src) +} +func (m *RedisPubsub) XXX_Size() int { + return xxx_messageInfo_RedisPubsub.Size(m) +} +func (m *RedisPubsub) XXX_DiscardUnknown() { + xxx_messageInfo_RedisPubsub.DiscardUnknown(m) +} + +var xxx_messageInfo_RedisPubsub proto.InternalMessageInfo + +func (m *RedisPubsub) GetAddress() string { + if m != nil { + return m.Address + } + return "" +} + +func (m *RedisPubsub) GetDatabase() int32 { + if m != nil { + return m.Database + } + return 0 +} + +func (m *RedisPubsub) GetUsername() string { + if m != nil { + return m.Username + } + return "" +} + +func (m *RedisPubsub) GetPassword() string { + if m != nil { + return m.Password + } + return "" +} + +func (m *RedisPubsub) GetChannels() []string { + if m != nil { + return m.Channels + } + return nil +} + +func init() { + proto.RegisterType((*RedisPubsub)(nil), "destinations.RedisPubsub") +} + +func init() { + proto.RegisterFile("events/destinations/redis-pubsub.proto", fileDescriptor_35320f6d09c25866) +} + +var fileDescriptor_35320f6d09c25866 = []byte{ + // 206 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x8f, 0xbf, 0x4e, 0xc5, 0x20, + 0x14, 0x87, 0x83, 0xb5, 0xfe, 0x41, 0xa7, 0x4e, 0xc4, 0xa9, 0x71, 0x30, 0x5d, 0x2c, 0x83, 0x93, + 0x71, 0xf3, 0x09, 0x4c, 0x47, 0xb7, 0x03, 0x9c, 0x14, 0x92, 0x16, 0x08, 0x07, 0xf4, 0x51, 0x7c, + 0x5d, 0x43, 0x6f, 0xda, 0xdc, 0xe1, 0x8e, 0x5f, 0xbe, 0xef, 0x37, 0xfc, 0xf8, 0x0b, 0xfe, 0xa0, + 0xcf, 0x24, 0x0d, 0x52, 0x76, 0x1e, 0xb2, 0x0b, 0x9e, 0x64, 0x42, 0xe3, 0xe8, 0x35, 0x16, 0x45, + 0x45, 0x8d, 0x31, 0x85, 0x1c, 0xba, 0xc7, 0xf3, 0xe0, 0xf9, 0x8f, 0xf1, 0x87, 0xa9, 0x46, 0x5f, + 0x5b, 0xd3, 0x09, 0x7e, 0x0b, 0xc6, 0x24, 0x24, 0x12, 0xac, 0x67, 0xc3, 0xfd, 0xb4, 0x63, 0xf7, + 0xc4, 0xef, 0x0c, 0x64, 0x50, 0x40, 0x28, 0xae, 0x7a, 0x36, 0xb4, 0xd3, 0xc1, 0xd5, 0x15, 0xc2, + 0xe4, 0x61, 0x45, 0xd1, 0x6c, 0xb3, 0x83, 0xab, 0x8b, 0x40, 0xf4, 0x1b, 0x92, 0x11, 0xd7, 0x27, + 0xb7, 0x73, 0x75, 0xda, 0x82, 0xf7, 0xb8, 0x90, 0x68, 0xfb, 0xa6, 0xba, 0x9d, 0x3f, 0x3f, 0xbe, + 0xdf, 0x67, 0x97, 0x6d, 0x51, 0xa3, 0x0e, 0xab, 0x54, 0x90, 0xb5, 0xd5, 0x21, 0x45, 0x49, 0xda, + 0xe2, 0x0a, 0x24, 0x55, 0x71, 0x8b, 0x91, 0x73, 0x90, 0x17, 0x7e, 0xab, 0x9b, 0xed, 0xeb, 0xdb, + 0x7f, 0x00, 0x00, 0x00, 0xff, 0xff, 0xa6, 0x1c, 0xac, 0x05, 0x15, 0x01, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-stream.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-stream.pb.go new file mode 100644 index 00000000..2c110775 --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-stream.pb.go @@ -0,0 +1,117 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/destinations/redis-stream.proto + +package destinations + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type RedisStream struct { + Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"` + Username string `protobuf:"bytes,2,opt,name=username,proto3" json:"username,omitempty"` + Password string `protobuf:"bytes,3,opt,name=password,proto3" json:"password,omitempty"` + Stream []string `protobuf:"bytes,4,rep,name=stream,proto3" json:"stream,omitempty"` + Key string `protobuf:"bytes,5,opt,name=key,proto3" json:"key,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *RedisStream) Reset() { *m = RedisStream{} } +func (m *RedisStream) String() string { return proto.CompactTextString(m) } +func (*RedisStream) ProtoMessage() {} +func (*RedisStream) Descriptor() ([]byte, []int) { + return fileDescriptor_92b4ce5a6cf84cb0, []int{0} +} + +func (m *RedisStream) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_RedisStream.Unmarshal(m, b) +} +func (m *RedisStream) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_RedisStream.Marshal(b, m, deterministic) +} +func (m *RedisStream) XXX_Merge(src proto.Message) { + xxx_messageInfo_RedisStream.Merge(m, src) +} +func (m *RedisStream) XXX_Size() int { + return xxx_messageInfo_RedisStream.Size(m) +} +func (m *RedisStream) XXX_DiscardUnknown() { + xxx_messageInfo_RedisStream.DiscardUnknown(m) +} + +var xxx_messageInfo_RedisStream proto.InternalMessageInfo + +func (m *RedisStream) GetAddress() string { + if m != nil { + return m.Address + } + return "" +} + +func (m *RedisStream) GetUsername() string { + if m != nil { + return m.Username + } + return "" +} + +func (m *RedisStream) GetPassword() string { + if m != nil { + return m.Password + } + return "" +} + +func (m *RedisStream) GetStream() []string { + if m != nil { + return m.Stream + } + return nil +} + +func (m *RedisStream) GetKey() string { + if m != nil { + return m.Key + } + return "" +} + +func init() { + proto.RegisterType((*RedisStream)(nil), "destinations.RedisStream") +} + +func init() { + proto.RegisterFile("events/destinations/redis-stream.proto", fileDescriptor_92b4ce5a6cf84cb0) +} + +var fileDescriptor_92b4ce5a6cf84cb0 = []byte{ + // 206 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x8f, 0xbd, 0x6a, 0xc3, 0x30, + 0x14, 0x46, 0x71, 0xdd, 0xba, 0xb5, 0xda, 0xa1, 0x68, 0x28, 0xa2, 0x93, 0xe9, 0x50, 0xbc, 0xd4, + 0x1a, 0x3a, 0x95, 0x6e, 0x79, 0x04, 0x67, 0xcb, 0xa6, 0x9f, 0x8b, 0x2d, 0x12, 0x49, 0x46, 0x57, + 0x4e, 0xc8, 0x23, 0xe4, 0xad, 0x83, 0xe5, 0x38, 0x64, 0xc8, 0x76, 0x0f, 0xe7, 0xc0, 0xe5, 0x23, + 0xdf, 0xb0, 0x07, 0x17, 0x91, 0x6b, 0xc0, 0x68, 0x9c, 0x88, 0xc6, 0x3b, 0xe4, 0x01, 0xb4, 0xc1, + 0x1f, 0x8c, 0x01, 0x84, 0x6d, 0x86, 0xe0, 0xa3, 0xa7, 0x6f, 0xb7, 0xc1, 0xd7, 0x29, 0x23, 0xaf, + 0xed, 0x14, 0xad, 0x53, 0x43, 0x19, 0x79, 0x16, 0x5a, 0x07, 0x40, 0x64, 0x59, 0x95, 0xd5, 0x65, + 0xbb, 0x20, 0xfd, 0x24, 0x2f, 0x23, 0x42, 0x70, 0xc2, 0x02, 0x7b, 0x48, 0xea, 0xca, 0x93, 0x1b, + 0x04, 0xe2, 0xc1, 0x07, 0xcd, 0xf2, 0xd9, 0x2d, 0x4c, 0x3f, 0x48, 0x31, 0xff, 0x67, 0x8f, 0x55, + 0x5e, 0x97, 0xed, 0x85, 0xe8, 0x3b, 0xc9, 0xb7, 0x70, 0x64, 0x4f, 0x29, 0x9f, 0xce, 0xd5, 0xff, + 0xe6, 0xaf, 0x33, 0xb1, 0x1f, 0x65, 0xa3, 0xbc, 0xe5, 0x52, 0x44, 0xd5, 0x2b, 0x1f, 0x06, 0x8e, + 0xaa, 0x07, 0x2b, 0x90, 0xcb, 0xd1, 0xec, 0x34, 0xef, 0x3c, 0xbf, 0xb3, 0x54, 0x16, 0x69, 0xdd, + 0xef, 0x39, 0x00, 0x00, 0xff, 0xff, 0x24, 0x1f, 0xf1, 0x4f, 0x07, 0x01, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-streams.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-streams.pb.go new file mode 100644 index 00000000..5016f24b --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/destinations/redis-streams.pb.go @@ -0,0 +1,127 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/destinations/redis-streams.proto + +package destinations + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type RedisStreams struct { + Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"` + Database int32 `protobuf:"varint,2,opt,name=database,proto3" json:"database,omitempty"` + Username string `protobuf:"bytes,3,opt,name=username,proto3" json:"username,omitempty"` + Password string `protobuf:"bytes,4,opt,name=password,proto3" json:"password,omitempty"` + Streams []string `protobuf:"bytes,5,rep,name=streams,proto3" json:"streams,omitempty"` + WriteKey string `protobuf:"bytes,6,opt,name=write_key,json=writeKey,proto3" json:"write_key,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *RedisStreams) Reset() { *m = RedisStreams{} } +func (m *RedisStreams) String() string { return proto.CompactTextString(m) } +func (*RedisStreams) ProtoMessage() {} +func (*RedisStreams) Descriptor() ([]byte, []int) { + return fileDescriptor_acbc723c4990ddab, []int{0} +} + +func (m *RedisStreams) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_RedisStreams.Unmarshal(m, b) +} +func (m *RedisStreams) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_RedisStreams.Marshal(b, m, deterministic) +} +func (m *RedisStreams) XXX_Merge(src proto.Message) { + xxx_messageInfo_RedisStreams.Merge(m, src) +} +func (m *RedisStreams) XXX_Size() int { + return xxx_messageInfo_RedisStreams.Size(m) +} +func (m *RedisStreams) XXX_DiscardUnknown() { + xxx_messageInfo_RedisStreams.DiscardUnknown(m) +} + +var xxx_messageInfo_RedisStreams proto.InternalMessageInfo + +func (m *RedisStreams) GetAddress() string { + if m != nil { + return m.Address + } + return "" +} + +func (m *RedisStreams) GetDatabase() int32 { + if m != nil { + return m.Database + } + return 0 +} + +func (m *RedisStreams) GetUsername() string { + if m != nil { + return m.Username + } + return "" +} + +func (m *RedisStreams) GetPassword() string { + if m != nil { + return m.Password + } + return "" +} + +func (m *RedisStreams) GetStreams() []string { + if m != nil { + return m.Streams + } + return nil +} + +func (m *RedisStreams) GetWriteKey() string { + if m != nil { + return m.WriteKey + } + return "" +} + +func init() { + proto.RegisterType((*RedisStreams)(nil), "destinations.RedisStreams") +} + +func init() { + proto.RegisterFile("events/destinations/redis-streams.proto", fileDescriptor_acbc723c4990ddab) +} + +var fileDescriptor_acbc723c4990ddab = []byte{ + // 225 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x90, 0x31, 0x4f, 0xc3, 0x30, + 0x10, 0x85, 0x15, 0x4a, 0x0b, 0xb5, 0x3a, 0x65, 0xb2, 0x60, 0x89, 0x58, 0xe8, 0x42, 0x3d, 0x30, + 0x21, 0x36, 0x56, 0xb6, 0xb0, 0xb1, 0xa0, 0xb3, 0x7d, 0x6a, 0x2c, 0xb0, 0x1d, 0xdd, 0x5d, 0xa8, + 0xfa, 0xbb, 0xf8, 0x83, 0xc8, 0x49, 0x1b, 0x31, 0x30, 0x7e, 0xf7, 0xde, 0xd3, 0x3b, 0x3d, 0x75, + 0x8f, 0xdf, 0x98, 0x84, 0x8d, 0x47, 0x96, 0x90, 0x40, 0x42, 0x4e, 0x6c, 0x08, 0x7d, 0xe0, 0x07, + 0x16, 0x42, 0x88, 0xbc, 0xeb, 0x29, 0x4b, 0xae, 0x37, 0x7f, 0x1d, 0x77, 0x3f, 0x95, 0xda, 0xb4, + 0xc5, 0xf5, 0x36, 0x99, 0x6a, 0xad, 0xae, 0xc0, 0x7b, 0x42, 0x66, 0x5d, 0x35, 0xd5, 0x76, 0xdd, + 0x9e, 0xb1, 0xbe, 0x51, 0xd7, 0x1e, 0x04, 0x2c, 0x30, 0xea, 0x8b, 0xa6, 0xda, 0x2e, 0xdb, 0x99, + 0x8b, 0x36, 0x30, 0x52, 0x82, 0x88, 0x7a, 0x31, 0xc6, 0x66, 0x2e, 0x5a, 0x0f, 0xcc, 0x87, 0x4c, + 0x5e, 0x5f, 0x4e, 0xda, 0x99, 0x4b, 0xdb, 0xe9, 0x3b, 0xbd, 0x6c, 0x16, 0xa5, 0xed, 0x84, 0xf5, + 0xad, 0x5a, 0x1f, 0x28, 0x08, 0x7e, 0x7c, 0xe2, 0x51, 0xaf, 0xa6, 0xd8, 0x78, 0x78, 0xc5, 0xe3, + 0xcb, 0xf3, 0xfb, 0xd3, 0x3e, 0x48, 0x37, 0xd8, 0x9d, 0xcb, 0xd1, 0x58, 0x10, 0xd7, 0xb9, 0x4c, + 0xbd, 0x61, 0xd7, 0x61, 0x04, 0x36, 0x76, 0x08, 0x5f, 0xde, 0xec, 0xb3, 0xf9, 0x67, 0x14, 0xbb, + 0x1a, 0x77, 0x78, 0xfc, 0x0d, 0x00, 0x00, 0xff, 0xff, 0x3b, 0x41, 0x48, 0x8d, 0x32, 0x01, 0x00, + 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/message.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/message.pb.go index 2ca6d229..4ece7a91 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/message.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/message.pb.go @@ -26,9 +26,9 @@ const ( // Emitted by UI-BFF // Consumed by all collectors in order to pre-load collection configuration Message_CREATE_COLLECTION Message_Type = 0 - // Emitted by UI-BFF - // Consumed by writer in order to pre-generate and cache a protobuf - // message descriptor (to facilitate fast writes from HSB -> E*) + // Emitted by UI-BFF specifically for protobuf schemas. + // Consumed by athena-writer which generates a parquet schema (and + // emits STATUS_ELECT_SCHEMA) Message_CREATE_SCHEMA Message_Type = 1 // Emitted by UI-BFF // Consumed by collectors - causes cached config to be released @@ -68,7 +68,10 @@ const ( // parquet and/or sql schema. This is in turn used by collectors to // update their internal caches in order to facilitate (fast) // identification of inbound events. - Message_UPDATE_SCHEMA Message_Type = 10 + // + // UPDATE 05.05.2020 + // Schema-inference v2 does not use this message type. + Message_UPDATE_SCHEMA Message_Type = 10 // Deprecated: Do not use. // Emitted by any service (as of 11.17.2020) // Consumed by task service // @@ -110,10 +113,46 @@ const ( Message_UNLOCK_ACCOUNT Message_Type = 23 // Emitted by collectors when an event comes in that needs either a new or updated schema // Consumed only by schema-manager - Message_GENERATE_SCHEMA Message_Type = 24 + // + // UPDATE 05.05.2020 + // Schema-inference v2 does not use this message type. + Message_GENERATE_SCHEMA Message_Type = 24 // Deprecated: Do not use. // Emitted by UI-BFF (as of 03.17.2021) - // Consumed by schema-manager, writer, athena-writer + // Consumed by schema-manager Message_UPDATE_PROTOS Message_Type = 25 + // Emitted by athena-writer instances + // Consumed by schema-manager + Message_ELECT_SCHEMA Message_Type = 26 + // Emitted by schema-manager + // Consumed by athena-writer instances and schema-manager itself + Message_STATUS_ELECT_SCHEMA Message_Type = 27 + // Emitted by ui-bff + // Consumed by source-manager + Message_CREATE_SOURCE Message_Type = 28 + // Emitted by ui-bff + // Consumed by source-manager + Message_UPDATE_SOURCE Message_Type = 29 + // Emitted by ui-bff + // Consumed by source-manager + Message_DELETE_SOURCE Message_Type = 30 + // Emitted by ui-bff + // Consumed by source-manager + Message_PAUSE_SOURCE Message_Type = 31 + // Emitted by ui-bff + // Consumed by source-manager + Message_RESUME_SOURCE Message_Type = 32 + // Emitted by ui-bff + // Consumed by dproxy + Message_CREATE_API_TOKEN Message_Type = 33 + // Emitted by ui-bff + // Consumed by dproxy + Message_DELETE_API_TOKEN Message_Type = 34 + // Emitted by dproxy + // Consumed by dproxy and ui-bff + Message_CREATE_DYNAMIC_DESTINATION Message_Type = 35 + // Emitted by dproxy + // Consumed by dproxy and ui-bff + Message_DELETE_DYNAMIC_DESTINATION Message_Type = 36 ) var Message_Type_name = map[int32]string{ @@ -143,35 +182,57 @@ var Message_Type_name = map[int32]string{ 23: "UNLOCK_ACCOUNT", 24: "GENERATE_SCHEMA", 25: "UPDATE_PROTOS", + 26: "ELECT_SCHEMA", + 27: "STATUS_ELECT_SCHEMA", + 28: "CREATE_SOURCE", + 29: "UPDATE_SOURCE", + 30: "DELETE_SOURCE", + 31: "PAUSE_SOURCE", + 32: "RESUME_SOURCE", + 33: "CREATE_API_TOKEN", + 34: "DELETE_API_TOKEN", + 35: "CREATE_DYNAMIC_DESTINATION", + 36: "DELETE_DYNAMIC_DESTINATION", } var Message_Type_value = map[string]int32{ - "CREATE_COLLECTION": 0, - "CREATE_SCHEMA": 1, - "DELETE_COLLECTION": 2, - "CREATE_REPLAY": 3, - "DELETE_REPLAY": 4, - "UPDATE_REPLAY": 5, - "PAUSE_REPLAY": 6, - "RESUME_REPLAY": 7, - "FINISH_REPLAY": 8, - "ABORT_REPLAY": 9, - "UPDATE_SCHEMA": 10, - "CREATE_TASK": 11, - "UPDATE_TASK": 12, - "UPDATE_COLLECTION": 13, - "CREATE_DESTINATION": 14, - "UPDATE_DESTINATION": 15, - "DELETE_DESTINATION": 16, - "CREATE_ACCOUNT": 17, - "UPDATE_ACCOUNT": 18, - "DELETE_ACCOUNT": 19, - "STATUS_SUBSCRIPTION": 20, - "STATUS_STRIPE_WEBHOOK": 21, - "LOCK_ACCOUNT": 22, - "UNLOCK_ACCOUNT": 23, - "GENERATE_SCHEMA": 24, - "UPDATE_PROTOS": 25, + "CREATE_COLLECTION": 0, + "CREATE_SCHEMA": 1, + "DELETE_COLLECTION": 2, + "CREATE_REPLAY": 3, + "DELETE_REPLAY": 4, + "UPDATE_REPLAY": 5, + "PAUSE_REPLAY": 6, + "RESUME_REPLAY": 7, + "FINISH_REPLAY": 8, + "ABORT_REPLAY": 9, + "UPDATE_SCHEMA": 10, + "CREATE_TASK": 11, + "UPDATE_TASK": 12, + "UPDATE_COLLECTION": 13, + "CREATE_DESTINATION": 14, + "UPDATE_DESTINATION": 15, + "DELETE_DESTINATION": 16, + "CREATE_ACCOUNT": 17, + "UPDATE_ACCOUNT": 18, + "DELETE_ACCOUNT": 19, + "STATUS_SUBSCRIPTION": 20, + "STATUS_STRIPE_WEBHOOK": 21, + "LOCK_ACCOUNT": 22, + "UNLOCK_ACCOUNT": 23, + "GENERATE_SCHEMA": 24, + "UPDATE_PROTOS": 25, + "ELECT_SCHEMA": 26, + "STATUS_ELECT_SCHEMA": 27, + "CREATE_SOURCE": 28, + "UPDATE_SOURCE": 29, + "DELETE_SOURCE": 30, + "PAUSE_SOURCE": 31, + "RESUME_SOURCE": 32, + "CREATE_API_TOKEN": 33, + "DELETE_API_TOKEN": 34, + "CREATE_DYNAMIC_DESTINATION": 35, + "DELETE_DYNAMIC_DESTINATION": 36, } func (x Message_Type) String() string { @@ -198,6 +259,8 @@ type Message struct { // *Message_Account // *Message_Subscription // *Message_StripeWebhook + // *Message_Source + // *Message_ApiToken Event isMessage_Event `protobuf_oneof:"event"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -286,6 +349,14 @@ type Message_StripeWebhook struct { StripeWebhook *StripeWebhook `protobuf:"bytes,107,opt,name=stripe_webhook,json=stripeWebhook,proto3,oneof"` } +type Message_Source struct { + Source *Source `protobuf:"bytes,108,opt,name=source,proto3,oneof"` +} + +type Message_ApiToken struct { + ApiToken *APIToken `protobuf:"bytes,109,opt,name=api_token,json=apiToken,proto3,oneof"` +} + func (*Message_Collect) isMessage_Event() {} func (*Message_Replay) isMessage_Event() {} @@ -302,6 +373,10 @@ func (*Message_Subscription) isMessage_Event() {} func (*Message_StripeWebhook) isMessage_Event() {} +func (*Message_Source) isMessage_Event() {} + +func (*Message_ApiToken) isMessage_Event() {} + func (m *Message) GetEvent() isMessage_Event { if m != nil { return m.Event @@ -365,6 +440,20 @@ func (m *Message) GetStripeWebhook() *StripeWebhook { return nil } +func (m *Message) GetSource() *Source { + if x, ok := m.GetEvent().(*Message_Source); ok { + return x.Source + } + return nil +} + +func (m *Message) GetApiToken() *APIToken { + if x, ok := m.GetEvent().(*Message_ApiToken); ok { + return x.ApiToken + } + return nil +} + // XXX_OneofWrappers is for the internal use of the proto package. func (*Message) XXX_OneofWrappers() []interface{} { return []interface{}{ @@ -376,6 +465,8 @@ func (*Message) XXX_OneofWrappers() []interface{} { (*Message_Account)(nil), (*Message_Subscription)(nil), (*Message_StripeWebhook)(nil), + (*Message_Source)(nil), + (*Message_ApiToken)(nil), } } @@ -387,46 +478,55 @@ func init() { func init() { proto.RegisterFile("message.proto", fileDescriptor_33c57e4bae7b9afd) } var fileDescriptor_33c57e4bae7b9afd = []byte{ - // 646 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x5c, 0x94, 0xc1, 0x6f, 0xda, 0x3e, - 0x14, 0xc7, 0x43, 0x4b, 0xa1, 0x3f, 0x43, 0x20, 0x98, 0xd2, 0xa6, 0x3d, 0x55, 0x3d, 0x21, 0xfd, - 0x26, 0x90, 0xba, 0xc3, 0xa4, 0x1d, 0x26, 0x85, 0xe0, 0x2d, 0x51, 0x29, 0x41, 0x76, 0x50, 0xb5, - 0x5d, 0x50, 0x48, 0x5d, 0xc8, 0x0a, 0x24, 0xc2, 0x61, 0x53, 0xff, 0x97, 0x9d, 0xf7, 0x77, 0x4e, - 0x76, 0x6c, 0xe6, 0xec, 0x96, 0x7c, 0xbe, 0x9f, 0xe7, 0xfa, 0xbd, 0x97, 0x02, 0xcc, 0x2d, 0x65, - 0x2c, 0x5a, 0xd1, 0x41, 0xb6, 0x4f, 0xf3, 0x14, 0xd6, 0xe8, 0x0f, 0xba, 0xcb, 0xd9, 0x8d, 0x19, - 0xc5, 0x71, 0x7a, 0xd8, 0xe5, 0x05, 0xbe, 0x31, 0xe3, 0x74, 0xb3, 0xa1, 0xb1, 0x7a, 0x6d, 0xee, - 0x69, 0xb6, 0x89, 0xde, 0xe4, 0x1b, 0x48, 0x76, 0x2f, 0xa9, 0x4a, 0x58, 0xbc, 0xa6, 0xdb, 0x48, - 0x25, 0x39, 0x8d, 0xb6, 0xc7, 0xe7, 0x88, 0xbd, 0xca, 0xe7, 0xce, 0x33, 0x65, 0x79, 0xb2, 0x8b, - 0xf2, 0x24, 0xdd, 0x49, 0x04, 0xd9, 0x61, 0xc9, 0xe2, 0x7d, 0x92, 0x69, 0xcc, 0xfc, 0x49, 0x97, - 0xeb, 0x34, 0x95, 0x55, 0x77, 0xbf, 0xcf, 0x41, 0xfd, 0xb1, 0xb8, 0x2d, 0xec, 0x83, 0x6a, 0xfe, - 0x96, 0x51, 0xbb, 0x72, 0x5b, 0xe9, 0xb7, 0xee, 0x2f, 0x06, 0xc5, 0xb5, 0x07, 0x32, 0x1e, 0x84, - 0x6f, 0x19, 0xc5, 0xc2, 0x80, 0xb7, 0xa0, 0xca, 0x6f, 0x61, 0x9f, 0xdc, 0x56, 0xfa, 0x8d, 0xfb, - 0xa6, 0x32, 0x43, 0x1a, 0x6d, 0xb1, 0x48, 0xb8, 0xc1, 0x3b, 0xb0, 0x4f, 0xcb, 0x86, 0xbf, 0x7b, - 0x49, 0xb1, 0x48, 0xe0, 0xff, 0xa0, 0x2e, 0x07, 0x60, 0x3f, 0x0b, 0xa9, 0xad, 0x24, 0xb7, 0xc0, - 0x9e, 0x81, 0x95, 0x01, 0xfb, 0xa0, 0x56, 0x8c, 0xc7, 0xa6, 0xc2, 0x6d, 0x29, 0x17, 0x0b, 0xea, - 0x19, 0x58, 0xe6, 0xdc, 0x2c, 0xc6, 0x65, 0xbf, 0x94, 0x4d, 0x22, 0x28, 0x37, 0x8b, 0x1c, 0xde, - 0x81, 0x2a, 0x1f, 0x9f, 0xbd, 0xfa, 0xa7, 0x89, 0x88, 0xbd, 0x7a, 0x06, 0x16, 0x19, 0xfc, 0x00, - 0x1a, 0xda, 0x58, 0xed, 0xb5, 0x50, 0xbb, 0x4a, 0x1d, 0xff, 0x8d, 0x3c, 0x03, 0xeb, 0x26, 0xef, - 0x4e, 0x6e, 0xdb, 0x4e, 0xca, 0xdd, 0x39, 0x05, 0xe6, 0xdd, 0x49, 0x03, 0x7e, 0x04, 0x4d, 0x7d, - 0x53, 0xf6, 0x77, 0x51, 0x71, 0x5c, 0x00, 0xd1, 0x32, 0xcf, 0xc0, 0x25, 0x17, 0x7e, 0x02, 0x2d, - 0x96, 0xef, 0x93, 0x8c, 0x2e, 0xe4, 0x62, 0xed, 0x57, 0x51, 0xdd, 0x3b, 0x56, 0x8b, 0xf4, 0xa9, - 0x08, 0x3d, 0x03, 0x9b, 0x4c, 0x07, 0x77, 0xbf, 0xaa, 0xa0, 0xca, 0x37, 0x0b, 0x7b, 0xa0, 0xe3, - 0x62, 0xe4, 0x84, 0x68, 0xe1, 0x06, 0x93, 0x09, 0x72, 0x43, 0x3f, 0x98, 0x5a, 0x06, 0xec, 0x00, - 0x53, 0x62, 0xe2, 0x7a, 0xe8, 0xd1, 0xb1, 0x2a, 0xdc, 0x1c, 0xa3, 0x09, 0x2a, 0x9b, 0x27, 0x9a, - 0x89, 0xd1, 0x6c, 0xe2, 0x7c, 0xb5, 0x4e, 0x39, 0x92, 0xa6, 0x44, 0x55, 0x8e, 0xe6, 0xb3, 0xb1, - 0x66, 0x9d, 0x41, 0x0b, 0x34, 0x67, 0xce, 0x9c, 0x1c, 0x49, 0x8d, 0x4b, 0x18, 0x91, 0xf9, 0xe3, - 0x11, 0xd5, 0x39, 0xfa, 0xec, 0x4f, 0x7d, 0xe2, 0x29, 0x74, 0xce, 0xeb, 0x9c, 0x51, 0x80, 0x43, - 0x45, 0xfe, 0xd3, 0x0e, 0x97, 0x97, 0x05, 0xb0, 0x0d, 0x1a, 0xf2, 0x56, 0xa1, 0x43, 0x1e, 0xac, - 0x06, 0x07, 0xd2, 0x11, 0xa0, 0xc9, 0xdb, 0x91, 0x40, 0x6b, 0xc7, 0x84, 0x97, 0x00, 0xca, 0xc2, - 0x31, 0x22, 0xa1, 0x3f, 0x75, 0x04, 0x6f, 0x71, 0x2e, 0x75, 0x9d, 0xb7, 0x39, 0x97, 0xbd, 0xea, - 0xdc, 0x82, 0x10, 0xb4, 0xe4, 0x39, 0x8e, 0xeb, 0x06, 0xf3, 0x69, 0x68, 0x75, 0x38, 0x93, 0x67, - 0x28, 0x06, 0x39, 0x93, 0xf5, 0x8a, 0x75, 0xe1, 0x15, 0xe8, 0x92, 0xd0, 0x09, 0xe7, 0x64, 0x41, - 0xe6, 0x23, 0xe2, 0x62, 0x7f, 0x26, 0x0e, 0xbd, 0x80, 0xd7, 0xa0, 0xa7, 0x82, 0x10, 0xfb, 0x33, - 0xb4, 0x78, 0x42, 0x23, 0x2f, 0x08, 0x1e, 0xac, 0x1e, 0x9f, 0xca, 0x24, 0x70, 0x1f, 0x8e, 0xa7, - 0x5c, 0x8a, 0xbf, 0x36, 0x2d, 0xb1, 0x2b, 0xd8, 0x05, 0xed, 0x2f, 0x68, 0x8a, 0xb0, 0x36, 0x2b, - 0x5b, 0x1b, 0xdf, 0x0c, 0x07, 0x61, 0x40, 0xac, 0xeb, 0x51, 0x1d, 0x9c, 0x89, 0xef, 0x68, 0x34, - 0xf8, 0xf6, 0x6e, 0x95, 0xe4, 0xeb, 0xc3, 0x72, 0x10, 0xa7, 0xdb, 0xe1, 0x32, 0xca, 0xe3, 0x75, - 0x9c, 0xee, 0xb3, 0x61, 0xf1, 0xcf, 0xc4, 0x86, 0xcb, 0x43, 0xb2, 0x79, 0x1e, 0xae, 0xd2, 0x61, - 0xf1, 0xd9, 0x2d, 0x6b, 0xe2, 0xf7, 0xe5, 0xfd, 0x9f, 0x00, 0x00, 0x00, 0xff, 0xff, 0xda, 0x6b, - 0x54, 0x44, 0x0c, 0x05, 0x00, 0x00, + // 790 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x94, 0x5f, 0x6f, 0xe2, 0x46, + 0x14, 0xc5, 0x4d, 0x96, 0x85, 0xec, 0xf0, 0xcf, 0x4c, 0xc2, 0xc6, 0x4b, 0xdb, 0x2d, 0xa5, 0x7d, + 0x40, 0x6a, 0x05, 0x52, 0xfa, 0x50, 0xa9, 0x0f, 0x95, 0x8c, 0x99, 0xd6, 0x16, 0x60, 0x5b, 0x63, + 0xa3, 0x28, 0x7d, 0x41, 0xc6, 0x99, 0x80, 0xcb, 0x1f, 0x5b, 0xd8, 0xb4, 0xca, 0x47, 0xe9, 0x97, + 0xad, 0xaa, 0x19, 0xcf, 0x38, 0xe3, 0x68, 0xdf, 0x86, 0xdf, 0x39, 0x73, 0x99, 0x7b, 0xee, 0x05, + 0xd0, 0x3a, 0x92, 0x34, 0x0d, 0xb6, 0x64, 0x9c, 0x9c, 0xe3, 0x2c, 0x86, 0x35, 0xf2, 0x37, 0x39, + 0x65, 0x69, 0xbf, 0x15, 0x84, 0x61, 0x7c, 0x39, 0x65, 0x39, 0xee, 0xb7, 0xc2, 0xf8, 0x70, 0x20, + 0xa1, 0xf8, 0xd8, 0x3c, 0x93, 0xe4, 0x10, 0xbc, 0xf0, 0x4f, 0x20, 0x3a, 0x3d, 0xc7, 0x42, 0x49, + 0xc3, 0x1d, 0x39, 0x06, 0x42, 0xc9, 0x48, 0x70, 0x2c, 0xce, 0x41, 0xba, 0xe7, 0xe7, 0xee, 0x13, + 0x49, 0xb3, 0xe8, 0x14, 0x64, 0x51, 0x7c, 0xe2, 0x08, 0xa6, 0x97, 0x4d, 0x1a, 0x9e, 0xa3, 0x44, + 0x62, 0xad, 0x7f, 0xc8, 0x66, 0x17, 0xc7, 0xfb, 0xa2, 0x76, 0x7c, 0x39, 0x87, 0xfc, 0xa5, 0xfd, + 0x76, 0x90, 0x44, 0x59, 0xbc, 0x27, 0xdc, 0x3c, 0xfc, 0x0f, 0x80, 0xfa, 0x32, 0xef, 0x05, 0x8e, + 0x40, 0x35, 0x7b, 0x49, 0x88, 0x56, 0x19, 0x54, 0x46, 0xed, 0xfb, 0xdb, 0x71, 0xde, 0xd4, 0x98, + 0xcb, 0x63, 0xff, 0x25, 0x21, 0x98, 0x39, 0xe0, 0x00, 0x54, 0xe9, 0x1b, 0xb5, 0xab, 0x41, 0x65, + 0xd4, 0xb8, 0x6f, 0x0a, 0xa7, 0x4f, 0x82, 0x23, 0x66, 0x0a, 0x75, 0xd0, 0xfe, 0xb4, 0x77, 0x65, + 0x87, 0x75, 0x7a, 0x8e, 0x31, 0x53, 0xe0, 0x8f, 0xa0, 0xce, 0xe3, 0xd1, 0x9e, 0x98, 0xa9, 0x23, + 0x4c, 0x46, 0x8e, 0x4d, 0x05, 0x0b, 0x07, 0x1c, 0x81, 0x5a, 0x1e, 0x9e, 0x46, 0x98, 0xb7, 0x2d, + 0xbc, 0x98, 0x51, 0x53, 0xc1, 0x5c, 0xa7, 0xce, 0x3c, 0x4c, 0xed, 0xb9, 0xec, 0xf4, 0x18, 0xa5, + 0xce, 0x5c, 0x87, 0x43, 0x50, 0xa5, 0xe1, 0x6a, 0xdb, 0x37, 0x4d, 0x04, 0xe9, 0xde, 0x54, 0x30, + 0xd3, 0xe0, 0x2f, 0xa0, 0x21, 0x85, 0xae, 0xed, 0x98, 0xf5, 0x46, 0x58, 0x67, 0xaf, 0x92, 0xa9, + 0x60, 0xd9, 0x49, 0xbb, 0xe3, 0xbb, 0xa0, 0x45, 0xe5, 0xee, 0xf4, 0x1c, 0xd3, 0xee, 0xb8, 0x03, + 0xfe, 0x0a, 0x9a, 0xf2, 0x1c, 0xb5, 0xbf, 0xd8, 0x8d, 0x62, 0x00, 0x9e, 0xa4, 0x99, 0x0a, 0x2e, + 0x79, 0xe1, 0x6f, 0xa0, 0x9d, 0x66, 0xe7, 0x28, 0x21, 0x6b, 0x3e, 0x76, 0x6d, 0xcf, 0x6e, 0xf7, + 0x8a, 0xdb, 0x4c, 0x7d, 0xc8, 0x45, 0x53, 0xc1, 0xad, 0x54, 0x06, 0x2c, 0x2f, 0xb6, 0x20, 0xda, + 0xe1, 0x4d, 0x5e, 0x8c, 0xb2, 0xbc, 0xd8, 0x09, 0x4e, 0xc0, 0x87, 0x20, 0x89, 0xd6, 0x6c, 0x7b, + 0xb4, 0x23, 0x33, 0xab, 0x45, 0x53, 0xae, 0xe5, 0x53, 0x6e, 0x2a, 0xf8, 0x3a, 0x48, 0x22, 0x76, + 0x1e, 0xfe, 0x5b, 0x03, 0x55, 0xba, 0x34, 0xb0, 0x07, 0xba, 0x06, 0x46, 0xba, 0x8f, 0xd6, 0x86, + 0xb3, 0x58, 0x20, 0xc3, 0xb7, 0x1c, 0x5b, 0x55, 0x60, 0x17, 0xb4, 0x38, 0xf6, 0x0c, 0x13, 0x2d, + 0x75, 0xb5, 0x42, 0x9d, 0x33, 0xb4, 0x40, 0x65, 0xe7, 0x95, 0xe4, 0xc4, 0xc8, 0x5d, 0xe8, 0x8f, + 0xea, 0x3b, 0x8a, 0xb8, 0x93, 0xa3, 0x2a, 0x45, 0x2b, 0x77, 0x26, 0xb9, 0xde, 0x43, 0x15, 0x34, + 0x5d, 0x7d, 0xe5, 0x15, 0xa4, 0x46, 0x4d, 0x18, 0x79, 0xab, 0x65, 0x81, 0xea, 0x14, 0xfd, 0x6e, + 0xd9, 0x96, 0x67, 0x0a, 0x74, 0x4d, 0xef, 0xe9, 0x53, 0x07, 0xfb, 0x82, 0x7c, 0x80, 0xbd, 0xa2, + 0x38, 0x7f, 0x2c, 0xe8, 0x5f, 0x5d, 0x57, 0x60, 0x07, 0x34, 0xf8, 0xcb, 0x7c, 0xdd, 0x9b, 0xab, + 0x0d, 0x0a, 0xb8, 0x8f, 0x81, 0x26, 0x6d, 0x89, 0x03, 0xa9, 0xa5, 0x16, 0xfc, 0x08, 0x20, 0xbf, + 0x38, 0x43, 0x9e, 0x6f, 0xd9, 0x3a, 0xe3, 0x6d, 0xca, 0xb9, 0x5d, 0xe6, 0x1d, 0xca, 0x79, 0xbf, + 0x32, 0x57, 0x21, 0x04, 0x6d, 0x5e, 0x47, 0x37, 0x0c, 0x67, 0x65, 0xfb, 0x6a, 0x97, 0x32, 0x5e, + 0x43, 0x30, 0x48, 0x19, 0xbf, 0x2f, 0xd8, 0x0d, 0xbc, 0x03, 0x37, 0x9e, 0xaf, 0xfb, 0x2b, 0x6f, + 0xed, 0xad, 0xa6, 0x9e, 0x81, 0x2d, 0x97, 0x15, 0xbd, 0x85, 0x9f, 0x40, 0x4f, 0x08, 0x3e, 0xb6, + 0x5c, 0xb4, 0x7e, 0x40, 0x53, 0xd3, 0x71, 0xe6, 0x6a, 0x8f, 0x26, 0xb3, 0x70, 0x8c, 0x79, 0x51, + 0xe5, 0x23, 0xfb, 0x36, 0xbb, 0xc4, 0xee, 0xe0, 0x1d, 0xe8, 0xfc, 0x81, 0x6c, 0x84, 0xa5, 0xbc, + 0x34, 0x96, 0xd7, 0xeb, 0x8c, 0x5c, 0xec, 0xf8, 0x8e, 0xa7, 0x7e, 0xa2, 0x15, 0x11, 0xcd, 0x45, + 0x18, 0xfb, 0xd2, 0xbb, 0x4a, 0xc2, 0x57, 0xf2, 0xc6, 0x38, 0x2b, 0x6c, 0x20, 0xf5, 0x6b, 0xa9, + 0x20, 0x47, 0xdf, 0x48, 0xab, 0xc1, 0xd1, 0xe7, 0xd7, 0x3d, 0xe0, 0xe4, 0x5b, 0x69, 0x0f, 0x38, + 0x1a, 0xc0, 0x5b, 0xa0, 0x8a, 0x28, 0x5d, 0x6b, 0xed, 0x3b, 0x73, 0x64, 0xab, 0xdf, 0x51, 0x2a, + 0x82, 0x2b, 0xe8, 0x10, 0x7e, 0x06, 0x7d, 0x31, 0xbe, 0x47, 0x5b, 0x5f, 0x5a, 0x46, 0x69, 0x2c, + 0xdf, 0x53, 0x5d, 0x8c, 0xeb, 0x0b, 0xfa, 0x0f, 0xd3, 0x3a, 0x78, 0xcf, 0x7e, 0x3a, 0xd3, 0xf1, + 0x9f, 0x3f, 0x6d, 0xa3, 0x6c, 0x77, 0xd9, 0x8c, 0xc3, 0xf8, 0x38, 0xd9, 0x04, 0x59, 0xb8, 0x0b, + 0xe3, 0x73, 0x32, 0xc9, 0xff, 0xa4, 0xd2, 0xc9, 0xe6, 0x12, 0x1d, 0x9e, 0x26, 0xdb, 0x78, 0x92, + 0xff, 0xd2, 0x36, 0x35, 0xf6, 0xbf, 0xfd, 0xf3, 0xff, 0x01, 0x00, 0x00, 0xff, 0xff, 0x53, 0x90, + 0x34, 0xda, 0x82, 0x06, 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/metric.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/metric.pb.go index 9b592e0a..610eafa5 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/metric.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/metric.pb.go @@ -24,21 +24,21 @@ const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package type Metric_Type int32 const ( - Metric_UNSET Metric_Type = 0 - Metric_COUNTER Metric_Type = 1 - Metric_ERROR Metric_Type = 2 + Metric_UNSET Metric_Type = 0 + Metric_COUNTER Metric_Type = 1 + Metric_AUDITLOG Metric_Type = 2 ) var Metric_Type_name = map[int32]string{ 0: "UNSET", 1: "COUNTER", - 2: "ERROR", + 2: "AUDITLOG", } var Metric_Type_value = map[string]int32{ - "UNSET": 0, - "COUNTER": 1, - "ERROR": 2, + "UNSET": 0, + "COUNTER": 1, + "AUDITLOG": 2, } func (x Metric_Type) String() string { @@ -56,7 +56,7 @@ type Metric struct { Type Metric_Type `protobuf:"varint,1,opt,name=type,proto3,enum=events.Metric_Type" json:"type,omitempty"` // Types that are valid to be assigned to Event: // *Metric_Counter - // *Metric_Error + // *Metric_AuditLog Event isMetric_Event `protobuf_oneof:"event"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -103,13 +103,13 @@ type Metric_Counter struct { Counter *metrics.Counter `protobuf:"bytes,100,opt,name=counter,proto3,oneof"` } -type Metric_Error struct { - Error *metrics.Error `protobuf:"bytes,101,opt,name=error,proto3,oneof"` +type Metric_AuditLog struct { + AuditLog *metrics.AuditLog `protobuf:"bytes,101,opt,name=audit_log,json=auditLog,proto3,oneof"` } func (*Metric_Counter) isMetric_Event() {} -func (*Metric_Error) isMetric_Event() {} +func (*Metric_AuditLog) isMetric_Event() {} func (m *Metric) GetEvent() isMetric_Event { if m != nil { @@ -125,9 +125,9 @@ func (m *Metric) GetCounter() *metrics.Counter { return nil } -func (m *Metric) GetError() *metrics.Error { - if x, ok := m.GetEvent().(*Metric_Error); ok { - return x.Error +func (m *Metric) GetAuditLog() *metrics.AuditLog { + if x, ok := m.GetEvent().(*Metric_AuditLog); ok { + return x.AuditLog } return nil } @@ -136,7 +136,7 @@ func (m *Metric) GetError() *metrics.Error { func (*Metric) XXX_OneofWrappers() []interface{} { return []interface{}{ (*Metric_Counter)(nil), - (*Metric_Error)(nil), + (*Metric_AuditLog)(nil), } } @@ -148,21 +148,22 @@ func init() { func init() { proto.RegisterFile("metric.proto", fileDescriptor_da41641f55bff5df) } var fileDescriptor_da41641f55bff5df = []byte{ - // 244 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x3c, 0x8f, 0xc1, 0x6a, 0xc2, 0x40, - 0x10, 0x86, 0xb3, 0xc5, 0x24, 0x74, 0x2c, 0x12, 0x56, 0x0a, 0xc1, 0x93, 0x78, 0x68, 0x2d, 0xc8, - 0x2c, 0xd8, 0x37, 0x50, 0x02, 0x5e, 0xaa, 0xb0, 0x8d, 0x97, 0xde, 0xcc, 0x3a, 0x98, 0x40, 0xe3, - 0x86, 0xcd, 0xa6, 0xe0, 0xb3, 0xf5, 0xe5, 0x4a, 0x76, 0x63, 0xaf, 0xdf, 0xff, 0xf1, 0xcf, 0xfc, - 0xf0, 0x54, 0x93, 0x35, 0x95, 0xc2, 0xc6, 0x68, 0xab, 0x79, 0x44, 0x3f, 0x74, 0xb5, 0xed, 0xec, - 0xd9, 0xd3, 0x56, 0x28, 0xdd, 0x5d, 0x2d, 0x19, 0x1f, 0xcf, 0xa6, 0x77, 0x4c, 0xc6, 0xe8, 0x01, - 0x2e, 0x7e, 0x19, 0x44, 0x1f, 0x8e, 0xf3, 0x57, 0x18, 0xd9, 0x5b, 0x43, 0x29, 0x9b, 0xb3, 0xe5, - 0x64, 0x3d, 0x45, 0xdf, 0x86, 0x3e, 0xc5, 0xfc, 0xd6, 0x90, 0x74, 0x02, 0x5f, 0x41, 0x3c, 0x34, - 0xa7, 0xe7, 0x39, 0x5b, 0x8e, 0xd7, 0x09, 0x0e, 0xd5, 0xb8, 0xf5, 0x7c, 0x17, 0xc8, 0xbb, 0xc2, - 0x5f, 0x20, 0x74, 0x07, 0x53, 0x72, 0xee, 0xe4, 0xdf, 0xcd, 0x7a, 0xba, 0x0b, 0xa4, 0x8f, 0x17, - 0x6f, 0x30, 0xea, 0x6f, 0xf0, 0x47, 0x08, 0x8f, 0xfb, 0xcf, 0x2c, 0x4f, 0x02, 0x3e, 0x86, 0x78, - 0x7b, 0x38, 0xee, 0xf3, 0x4c, 0x26, 0xac, 0xe7, 0x99, 0x94, 0x07, 0x99, 0x3c, 0x6c, 0x62, 0x08, - 0xdd, 0x73, 0x1b, 0xfc, 0x5a, 0x5d, 0x2a, 0x5b, 0x76, 0x05, 0x2a, 0x5d, 0x8b, 0xe2, 0x64, 0x55, - 0xa9, 0xb4, 0x69, 0x44, 0xab, 0x4a, 0xaa, 0x4f, 0xad, 0x28, 0xba, 0xea, 0xfb, 0x2c, 0x2e, 0x5a, - 0xf8, 0x2d, 0x45, 0xe4, 0x46, 0xbf, 0xff, 0x05, 0x00, 0x00, 0xff, 0xff, 0x21, 0xfb, 0x63, 0xea, - 0x38, 0x01, 0x00, 0x00, + // 264 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x3c, 0x90, 0xc1, 0x6a, 0xc2, 0x30, + 0x1c, 0xc6, 0x9b, 0xa1, 0xad, 0xfe, 0x95, 0xd1, 0x65, 0x6c, 0x14, 0x4f, 0xe2, 0x65, 0x1e, 0x4a, + 0x32, 0xdc, 0x13, 0xa8, 0x93, 0x39, 0x70, 0x0a, 0x5d, 0x7b, 0xd9, 0x65, 0xb4, 0x69, 0x48, 0x0b, + 0xad, 0x29, 0x6d, 0x3a, 0xf0, 0x0d, 0xf7, 0x58, 0xc3, 0xa4, 0xdd, 0x2d, 0x7c, 0xbf, 0x1f, 0xdf, + 0x97, 0x04, 0xa6, 0x25, 0x57, 0x75, 0xce, 0x48, 0x55, 0x4b, 0x25, 0xb1, 0xcd, 0x7f, 0xf8, 0x59, + 0x35, 0xb3, 0x07, 0x93, 0x36, 0x94, 0xc9, 0xf6, 0xac, 0x78, 0x6d, 0xf0, 0xec, 0xb1, 0x8f, 0xe3, + 0x36, 0xcd, 0x55, 0x21, 0x85, 0xc9, 0x17, 0xbf, 0x08, 0xec, 0x0f, 0x8d, 0xf0, 0x13, 0x0c, 0xd4, + 0xa5, 0xe2, 0x1e, 0x9a, 0xa3, 0xe5, 0xed, 0xea, 0x9e, 0x98, 0x42, 0x62, 0x28, 0x09, 0x2f, 0x15, + 0x0f, 0xb4, 0x80, 0x7d, 0x70, 0xba, 0x72, 0x2f, 0x9d, 0xa3, 0xe5, 0x64, 0xe5, 0x92, 0xae, 0x9d, + 0x6c, 0x4d, 0xbe, 0xb7, 0x82, 0x5e, 0xc1, 0xcf, 0x30, 0xd6, 0x9b, 0xdf, 0x85, 0x14, 0x1e, 0xd7, + 0xfe, 0xdd, 0xbf, 0xbf, 0xbe, 0x92, 0x83, 0x14, 0x7b, 0x2b, 0x18, 0xc5, 0xdd, 0x79, 0xe1, 0xc3, + 0xe0, 0xba, 0x86, 0xc7, 0x30, 0x8c, 0x8e, 0x9f, 0xbb, 0xd0, 0xb5, 0xf0, 0x04, 0x9c, 0xed, 0x29, + 0x3a, 0x86, 0xbb, 0xc0, 0x45, 0x78, 0x0a, 0xa3, 0x75, 0xf4, 0xfa, 0x1e, 0x1e, 0x4e, 0x6f, 0xee, + 0xcd, 0xc6, 0x81, 0xa1, 0xbe, 0xe9, 0x86, 0x7c, 0xf9, 0x22, 0x57, 0x59, 0x9b, 0x10, 0x26, 0x4b, + 0x9a, 0xc4, 0x8a, 0x65, 0x4c, 0xd6, 0x15, 0x6d, 0x58, 0xc6, 0xcb, 0xb8, 0xa1, 0x49, 0x9b, 0x17, + 0x29, 0x15, 0x92, 0x9a, 0x87, 0x25, 0xb6, 0xfe, 0x81, 0x97, 0xbf, 0x00, 0x00, 0x00, 0xff, 0xff, + 0x89, 0x38, 0x20, 0x45, 0x48, 0x01, 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/metrics/auditlog.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/metrics/auditlog.pb.go new file mode 100644 index 00000000..ecad7f27 --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/metrics/auditlog.pb.go @@ -0,0 +1,244 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/metrics/auditlog.proto + +package metrics + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type AuditLog_Resource int32 + +const ( + AuditLog_UNSET AuditLog_Resource = 0 + AuditLog_COLLECTION AuditLog_Resource = 1 + AuditLog_REPLAY AuditLog_Resource = 2 + AuditLog_STORAGE AuditLog_Resource = 3 + AuditLog_DESTINATION AuditLog_Resource = 4 + AuditLog_SCHEMA AuditLog_Resource = 5 + AuditLog_SEARCH AuditLog_Resource = 6 + AuditLog_TASK AuditLog_Resource = 7 + AuditLog_BILLING AuditLog_Resource = 8 +) + +var AuditLog_Resource_name = map[int32]string{ + 0: "UNSET", + 1: "COLLECTION", + 2: "REPLAY", + 3: "STORAGE", + 4: "DESTINATION", + 5: "SCHEMA", + 6: "SEARCH", + 7: "TASK", + 8: "BILLING", +} + +var AuditLog_Resource_value = map[string]int32{ + "UNSET": 0, + "COLLECTION": 1, + "REPLAY": 2, + "STORAGE": 3, + "DESTINATION": 4, + "SCHEMA": 5, + "SEARCH": 6, + "TASK": 7, + "BILLING": 8, +} + +func (x AuditLog_Resource) String() string { + return proto.EnumName(AuditLog_Resource_name, int32(x)) +} + +func (AuditLog_Resource) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_ae2ce3e11a0fe8d5, []int{0, 0} +} + +type AuditLog_Type int32 + +const ( + AuditLog_UNKNOWN AuditLog_Type = 0 + AuditLog_INFO AuditLog_Type = 1 + AuditLog_WARNING AuditLog_Type = 2 + AuditLog_ERROR AuditLog_Type = 3 + AuditLog_FATAL AuditLog_Type = 4 +) + +var AuditLog_Type_name = map[int32]string{ + 0: "UNKNOWN", + 1: "INFO", + 2: "WARNING", + 3: "ERROR", + 4: "FATAL", +} + +var AuditLog_Type_value = map[string]int32{ + "UNKNOWN": 0, + "INFO": 1, + "WARNING": 2, + "ERROR": 3, + "FATAL": 4, +} + +func (x AuditLog_Type) String() string { + return proto.EnumName(AuditLog_Type_name, int32(x)) +} + +func (AuditLog_Type) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_ae2ce3e11a0fe8d5, []int{0, 1} +} + +// Used for internal error reporting using mlib library and metrics service. +type AuditLog struct { + Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` + TeamId string `protobuf:"bytes,2,opt,name=team_id,json=teamId,proto3" json:"team_id,omitempty"` + Resource AuditLog_Resource `protobuf:"varint,3,opt,name=resource,proto3,enum=metrics.AuditLog_Resource" json:"resource,omitempty"` + Source string `protobuf:"bytes,4,opt,name=source,proto3" json:"source,omitempty"` + Value string `protobuf:"bytes,5,opt,name=value,proto3" json:"value,omitempty"` + Timestamp int64 `protobuf:"varint,6,opt,name=timestamp,proto3" json:"timestamp,omitempty"` + Count int64 `protobuf:"varint,7,opt,name=count,proto3" json:"count,omitempty"` + Type AuditLog_Type `protobuf:"varint,8,opt,name=type,proto3,enum=metrics.AuditLog_Type" json:"type,omitempty"` + Metadata []byte `protobuf:"bytes,9,opt,name=Metadata,proto3" json:"Metadata,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *AuditLog) Reset() { *m = AuditLog{} } +func (m *AuditLog) String() string { return proto.CompactTextString(m) } +func (*AuditLog) ProtoMessage() {} +func (*AuditLog) Descriptor() ([]byte, []int) { + return fileDescriptor_ae2ce3e11a0fe8d5, []int{0} +} + +func (m *AuditLog) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_AuditLog.Unmarshal(m, b) +} +func (m *AuditLog) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_AuditLog.Marshal(b, m, deterministic) +} +func (m *AuditLog) XXX_Merge(src proto.Message) { + xxx_messageInfo_AuditLog.Merge(m, src) +} +func (m *AuditLog) XXX_Size() int { + return xxx_messageInfo_AuditLog.Size(m) +} +func (m *AuditLog) XXX_DiscardUnknown() { + xxx_messageInfo_AuditLog.DiscardUnknown(m) +} + +var xxx_messageInfo_AuditLog proto.InternalMessageInfo + +func (m *AuditLog) GetId() string { + if m != nil { + return m.Id + } + return "" +} + +func (m *AuditLog) GetTeamId() string { + if m != nil { + return m.TeamId + } + return "" +} + +func (m *AuditLog) GetResource() AuditLog_Resource { + if m != nil { + return m.Resource + } + return AuditLog_UNSET +} + +func (m *AuditLog) GetSource() string { + if m != nil { + return m.Source + } + return "" +} + +func (m *AuditLog) GetValue() string { + if m != nil { + return m.Value + } + return "" +} + +func (m *AuditLog) GetTimestamp() int64 { + if m != nil { + return m.Timestamp + } + return 0 +} + +func (m *AuditLog) GetCount() int64 { + if m != nil { + return m.Count + } + return 0 +} + +func (m *AuditLog) GetType() AuditLog_Type { + if m != nil { + return m.Type + } + return AuditLog_UNKNOWN +} + +func (m *AuditLog) GetMetadata() []byte { + if m != nil { + return m.Metadata + } + return nil +} + +func init() { + proto.RegisterEnum("metrics.AuditLog_Resource", AuditLog_Resource_name, AuditLog_Resource_value) + proto.RegisterEnum("metrics.AuditLog_Type", AuditLog_Type_name, AuditLog_Type_value) + proto.RegisterType((*AuditLog)(nil), "metrics.AuditLog") +} + +func init() { proto.RegisterFile("events/metrics/auditlog.proto", fileDescriptor_ae2ce3e11a0fe8d5) } + +var fileDescriptor_ae2ce3e11a0fe8d5 = []byte{ + // 419 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x64, 0x92, 0xcf, 0x6b, 0x9c, 0x40, + 0x14, 0xc7, 0xe3, 0x8f, 0x55, 0xf7, 0xa5, 0x6c, 0x87, 0xa1, 0xa4, 0x12, 0x5a, 0x58, 0xf6, 0xb4, + 0xf4, 0xa0, 0xd0, 0x96, 0x9c, 0x3b, 0xd9, 0x9a, 0x44, 0x62, 0xc6, 0x32, 0x1a, 0x42, 0x7b, 0x29, + 0xb3, 0x3a, 0xb8, 0xc2, 0x9a, 0x11, 0x1d, 0x03, 0xb9, 0xf4, 0xdf, 0xec, 0xbf, 0x53, 0xc6, 0x35, + 0x5b, 0x4a, 0x6f, 0xf3, 0xfd, 0xcc, 0xe7, 0x3d, 0xbe, 0x87, 0x07, 0xef, 0xc5, 0x93, 0x78, 0x54, + 0x7d, 0xd8, 0x08, 0xd5, 0xd5, 0x45, 0x1f, 0xf2, 0xa1, 0xac, 0xd5, 0x5e, 0x56, 0x41, 0xdb, 0x49, + 0x25, 0xb1, 0x3b, 0xf1, 0xd5, 0x6f, 0x0b, 0x3c, 0xa2, 0xff, 0x12, 0x59, 0xe1, 0x05, 0x98, 0x75, + 0xe9, 0x1b, 0x4b, 0x63, 0x3d, 0x67, 0x66, 0x5d, 0xe2, 0xb7, 0xe0, 0x2a, 0xc1, 0x9b, 0x9f, 0x75, + 0xe9, 0x9b, 0x23, 0x74, 0x74, 0x8c, 0x4b, 0x7c, 0x01, 0x5e, 0x27, 0x7a, 0x39, 0x74, 0x85, 0xf0, + 0xad, 0xa5, 0xb1, 0x5e, 0x7c, 0x3c, 0x0f, 0xa6, 0x8d, 0xc1, 0xcb, 0xb6, 0x80, 0x4d, 0x06, 0x3b, + 0xba, 0xf8, 0x0c, 0x9c, 0x69, 0xca, 0x3e, 0xec, 0x9b, 0xf8, 0x1b, 0x98, 0x3d, 0xf1, 0xfd, 0x20, + 0xfc, 0xd9, 0x88, 0x0f, 0x01, 0xbf, 0x83, 0xb9, 0xaa, 0x1b, 0xd1, 0x2b, 0xde, 0xb4, 0xbe, 0xb3, + 0x34, 0xd6, 0x16, 0xfb, 0x0b, 0xf4, 0x4c, 0x21, 0x87, 0x47, 0xe5, 0xbb, 0xe3, 0xcf, 0x21, 0xe0, + 0x0f, 0x60, 0xab, 0xe7, 0x56, 0xf8, 0xde, 0xd8, 0xea, 0xec, 0xff, 0x56, 0xf9, 0x73, 0x2b, 0xd8, + 0xe8, 0xe0, 0x73, 0xf0, 0xee, 0x84, 0xe2, 0x25, 0x57, 0xdc, 0x9f, 0x2f, 0x8d, 0xf5, 0x2b, 0x76, + 0xcc, 0xab, 0x5f, 0xe0, 0xbd, 0xf4, 0xc7, 0x73, 0x98, 0xdd, 0xd3, 0x2c, 0xca, 0xd1, 0x09, 0x5e, + 0x00, 0x6c, 0xd2, 0x24, 0x89, 0x36, 0x79, 0x9c, 0x52, 0x64, 0x60, 0x00, 0x87, 0x45, 0xdf, 0x12, + 0xf2, 0x1d, 0x99, 0xf8, 0x14, 0xdc, 0x2c, 0x4f, 0x19, 0xb9, 0x8e, 0x90, 0x85, 0x5f, 0xc3, 0xe9, + 0xd7, 0x28, 0xcb, 0x63, 0x4a, 0x46, 0xd3, 0xd6, 0x66, 0xb6, 0xb9, 0x89, 0xee, 0x08, 0x9a, 0x8d, + 0xef, 0x88, 0xb0, 0xcd, 0x0d, 0x72, 0xb0, 0x07, 0x76, 0x4e, 0xb2, 0x5b, 0xe4, 0xea, 0xf9, 0xcb, + 0x38, 0x49, 0x62, 0x7a, 0x8d, 0xbc, 0xd5, 0x17, 0xb0, 0x75, 0x53, 0x0d, 0xef, 0xe9, 0x2d, 0x4d, + 0x1f, 0x28, 0x3a, 0xd1, 0x6e, 0x4c, 0xaf, 0x52, 0x64, 0x68, 0xfc, 0x40, 0x18, 0xd5, 0xae, 0xa9, + 0xfb, 0x45, 0x8c, 0xa5, 0x0c, 0x59, 0xfa, 0x79, 0x45, 0x72, 0x92, 0x20, 0xfb, 0xf2, 0xe2, 0xc7, + 0xe7, 0xaa, 0x56, 0xbb, 0x61, 0x1b, 0x14, 0xb2, 0x09, 0xb7, 0x5c, 0x15, 0xbb, 0x42, 0x76, 0x6d, + 0xd8, 0x17, 0x3b, 0xd1, 0xf0, 0x3e, 0xdc, 0x0e, 0xf5, 0xbe, 0x0c, 0x2b, 0x19, 0xfe, 0x7b, 0x29, + 0x5b, 0x67, 0xbc, 0x90, 0x4f, 0x7f, 0x02, 0x00, 0x00, 0xff, 0xff, 0x38, 0xee, 0x93, 0x8b, 0x42, + 0x02, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/metrics/error.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/metrics/error.pb.go deleted file mode 100644 index e70fadbf..00000000 --- a/vendor/github.com/batchcorp/schemas/build/go/events/metrics/error.pb.go +++ /dev/null @@ -1,187 +0,0 @@ -// Code generated by protoc-gen-go. DO NOT EDIT. -// source: events/metrics/error.proto - -package metrics - -import ( - fmt "fmt" - proto "github.com/golang/protobuf/proto" - math "math" -) - -// Reference imports to suppress errors if they are not otherwise used. -var _ = proto.Marshal -var _ = fmt.Errorf -var _ = math.Inf - -// This is a compile-time assertion to ensure that this generated file -// is compatible with the proto package it is being compiled against. -// A compilation error at this line likely means your copy of the -// proto package needs to be updated. -const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package - -type Error_Type int32 - -const ( - Error_UNSET Error_Type = 0 - Error_COLLECTION Error_Type = 1 - Error_REPLAY Error_Type = 2 - Error_STORAGE Error_Type = 3 - Error_DESTINATION Error_Type = 4 - Error_SCHEMA Error_Type = 5 - Error_SEARCH Error_Type = 6 - Error_TASK Error_Type = 7 - Error_BILLING Error_Type = 8 -) - -var Error_Type_name = map[int32]string{ - 0: "UNSET", - 1: "COLLECTION", - 2: "REPLAY", - 3: "STORAGE", - 4: "DESTINATION", - 5: "SCHEMA", - 6: "SEARCH", - 7: "TASK", - 8: "BILLING", -} - -var Error_Type_value = map[string]int32{ - "UNSET": 0, - "COLLECTION": 1, - "REPLAY": 2, - "STORAGE": 3, - "DESTINATION": 4, - "SCHEMA": 5, - "SEARCH": 6, - "TASK": 7, - "BILLING": 8, -} - -func (x Error_Type) String() string { - return proto.EnumName(Error_Type_name, int32(x)) -} - -func (Error_Type) EnumDescriptor() ([]byte, []int) { - return fileDescriptor_f84d81ae4efc9ce4, []int{0, 0} -} - -// Used for internal error reporting using mlib library and metrics service. -type Error struct { - Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` - TeamId string `protobuf:"bytes,2,opt,name=team_id,json=teamId,proto3" json:"team_id,omitempty"` - Type Error_Type `protobuf:"varint,3,opt,name=type,proto3,enum=metrics.Error_Type" json:"type,omitempty"` - Source string `protobuf:"bytes,4,opt,name=source,proto3" json:"source,omitempty"` - Value string `protobuf:"bytes,5,opt,name=value,proto3" json:"value,omitempty"` - Timestamp int64 `protobuf:"varint,6,opt,name=timestamp,proto3" json:"timestamp,omitempty"` - Count int64 `protobuf:"varint,7,opt,name=count,proto3" json:"count,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *Error) Reset() { *m = Error{} } -func (m *Error) String() string { return proto.CompactTextString(m) } -func (*Error) ProtoMessage() {} -func (*Error) Descriptor() ([]byte, []int) { - return fileDescriptor_f84d81ae4efc9ce4, []int{0} -} - -func (m *Error) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_Error.Unmarshal(m, b) -} -func (m *Error) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_Error.Marshal(b, m, deterministic) -} -func (m *Error) XXX_Merge(src proto.Message) { - xxx_messageInfo_Error.Merge(m, src) -} -func (m *Error) XXX_Size() int { - return xxx_messageInfo_Error.Size(m) -} -func (m *Error) XXX_DiscardUnknown() { - xxx_messageInfo_Error.DiscardUnknown(m) -} - -var xxx_messageInfo_Error proto.InternalMessageInfo - -func (m *Error) GetId() string { - if m != nil { - return m.Id - } - return "" -} - -func (m *Error) GetTeamId() string { - if m != nil { - return m.TeamId - } - return "" -} - -func (m *Error) GetType() Error_Type { - if m != nil { - return m.Type - } - return Error_UNSET -} - -func (m *Error) GetSource() string { - if m != nil { - return m.Source - } - return "" -} - -func (m *Error) GetValue() string { - if m != nil { - return m.Value - } - return "" -} - -func (m *Error) GetTimestamp() int64 { - if m != nil { - return m.Timestamp - } - return 0 -} - -func (m *Error) GetCount() int64 { - if m != nil { - return m.Count - } - return 0 -} - -func init() { - proto.RegisterEnum("metrics.Error_Type", Error_Type_name, Error_Type_value) - proto.RegisterType((*Error)(nil), "metrics.Error") -} - -func init() { proto.RegisterFile("events/metrics/error.proto", fileDescriptor_f84d81ae4efc9ce4) } - -var fileDescriptor_f84d81ae4efc9ce4 = []byte{ - // 333 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x54, 0x91, 0x4d, 0x4b, 0xc3, 0x40, - 0x10, 0x86, 0x4d, 0x9a, 0x8f, 0x76, 0x0a, 0x75, 0x59, 0x45, 0x83, 0x78, 0x28, 0xbd, 0xd8, 0x53, - 0x02, 0x2a, 0xde, 0xd3, 0xb8, 0xb4, 0xc1, 0x98, 0x4a, 0x12, 0x0f, 0x7a, 0x91, 0x7c, 0x2c, 0x6d, - 0xa0, 0xe9, 0x86, 0xcd, 0xa6, 0x50, 0xff, 0x98, 0x7f, 0x4f, 0xb2, 0x29, 0x88, 0xb7, 0x7d, 0x9e, - 0x79, 0xe7, 0xdd, 0xc3, 0xc0, 0x0d, 0x3d, 0xd0, 0xbd, 0x68, 0x9c, 0x8a, 0x0a, 0x5e, 0xe6, 0x8d, - 0x43, 0x39, 0x67, 0xdc, 0xae, 0x39, 0x13, 0x0c, 0x9b, 0x27, 0x39, 0xfb, 0x51, 0x41, 0x27, 0xdd, - 0x00, 0x4f, 0x40, 0x2d, 0x0b, 0x4b, 0x99, 0x2a, 0xf3, 0x51, 0xa4, 0x96, 0x05, 0xbe, 0x06, 0x53, - 0xd0, 0xb4, 0xfa, 0x2a, 0x0b, 0x4b, 0x95, 0xd2, 0xe8, 0xd0, 0x2f, 0xf0, 0x1d, 0x68, 0xe2, 0x58, - 0x53, 0x6b, 0x30, 0x55, 0xe6, 0x93, 0xfb, 0x0b, 0xfb, 0x54, 0x65, 0xcb, 0x1a, 0x3b, 0x39, 0xd6, - 0x34, 0x92, 0x01, 0x7c, 0x05, 0x46, 0xc3, 0x5a, 0x9e, 0x53, 0x4b, 0xeb, 0x0b, 0x7a, 0xc2, 0x97, - 0xa0, 0x1f, 0xd2, 0x5d, 0x4b, 0x2d, 0x5d, 0xea, 0x1e, 0xf0, 0x2d, 0x8c, 0x44, 0x59, 0xd1, 0x46, - 0xa4, 0x55, 0x6d, 0x19, 0x53, 0x65, 0x3e, 0x88, 0xfe, 0x44, 0xb7, 0x93, 0xb3, 0x76, 0x2f, 0x2c, - 0x53, 0x4e, 0x7a, 0x98, 0x7d, 0x83, 0xd6, 0xfd, 0x87, 0x47, 0xa0, 0xbf, 0x87, 0x31, 0x49, 0xd0, - 0x19, 0x9e, 0x00, 0x78, 0xeb, 0x20, 0x20, 0x5e, 0xe2, 0xaf, 0x43, 0xa4, 0x60, 0x00, 0x23, 0x22, - 0x6f, 0x81, 0xfb, 0x81, 0x54, 0x3c, 0x06, 0x33, 0x4e, 0xd6, 0x91, 0xbb, 0x24, 0x68, 0x80, 0xcf, - 0x61, 0xfc, 0x4c, 0xe2, 0xc4, 0x0f, 0x5d, 0x99, 0xd4, 0xba, 0x64, 0xec, 0xad, 0xc8, 0xab, 0x8b, - 0x74, 0xf9, 0x26, 0x6e, 0xe4, 0xad, 0x90, 0x81, 0x87, 0xa0, 0x25, 0x6e, 0xfc, 0x82, 0xcc, 0x6e, - 0x7f, 0xe1, 0x07, 0x81, 0x1f, 0x2e, 0xd1, 0x70, 0xf1, 0xf4, 0xf9, 0xb8, 0x29, 0xc5, 0xb6, 0xcd, - 0xec, 0x9c, 0x55, 0x4e, 0x96, 0x8a, 0x7c, 0x9b, 0x33, 0x5e, 0x3b, 0x4d, 0xbe, 0xa5, 0x55, 0xda, - 0x38, 0x59, 0x5b, 0xee, 0x0a, 0x67, 0xc3, 0x9c, 0xff, 0x67, 0xc8, 0x0c, 0x79, 0x81, 0x87, 0xdf, - 0x00, 0x00, 0x00, 0xff, 0xff, 0xad, 0x4f, 0xef, 0x7f, 0x9f, 0x01, 0x00, 0x00, -} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/records/mqtt.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/records/mqtt.pb.go new file mode 100644 index 00000000..afbe465a --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/records/mqtt.pb.go @@ -0,0 +1,133 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: events/records/mqtt.proto + +package records + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type MQTTRecord 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"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *MQTTRecord) Reset() { *m = MQTTRecord{} } +func (m *MQTTRecord) String() string { return proto.CompactTextString(m) } +func (*MQTTRecord) ProtoMessage() {} +func (*MQTTRecord) Descriptor() ([]byte, []int) { + return fileDescriptor_c391d35771173aef, []int{0} +} + +func (m *MQTTRecord) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_MQTTRecord.Unmarshal(m, b) +} +func (m *MQTTRecord) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_MQTTRecord.Marshal(b, m, deterministic) +} +func (m *MQTTRecord) XXX_Merge(src proto.Message) { + xxx_messageInfo_MQTTRecord.Merge(m, src) +} +func (m *MQTTRecord) XXX_Size() int { + return xxx_messageInfo_MQTTRecord.Size(m) +} +func (m *MQTTRecord) XXX_DiscardUnknown() { + xxx_messageInfo_MQTTRecord.DiscardUnknown(m) +} + +var xxx_messageInfo_MQTTRecord proto.InternalMessageInfo + +func (m *MQTTRecord) GetId() uint32 { + if m != nil { + return m.Id + } + return 0 +} + +func (m *MQTTRecord) GetTopic() string { + if m != nil { + return m.Topic + } + return "" +} + +func (m *MQTTRecord) GetValue() []byte { + if m != nil { + return m.Value + } + return nil +} + +func (m *MQTTRecord) GetDuplicate() bool { + if m != nil { + return m.Duplicate + } + return false +} + +func (m *MQTTRecord) GetRetained() bool { + if m != nil { + return m.Retained + } + return false +} + +func (m *MQTTRecord) GetQos() uint32 { + if m != nil { + return m.Qos + } + return 0 +} + +func (m *MQTTRecord) GetTimestamp() int64 { + if m != nil { + return m.Timestamp + } + return 0 +} + +func init() { + proto.RegisterType((*MQTTRecord)(nil), "records.MQTTRecord") +} + +func init() { proto.RegisterFile("events/records/mqtt.proto", fileDescriptor_c391d35771173aef) } + +var fileDescriptor_c391d35771173aef = []byte{ + // 237 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x54, 0x90, 0xcd, 0x4e, 0xc4, 0x20, + 0x14, 0x85, 0x43, 0xeb, 0xfc, 0x11, 0x35, 0x86, 0x98, 0x88, 0xc6, 0x05, 0x71, 0xc5, 0x0a, 0x16, + 0xfa, 0x04, 0xee, 0x8d, 0x91, 0xcc, 0xca, 0x1d, 0x05, 0x32, 0x25, 0x29, 0x03, 0x03, 0xb7, 0xf3, + 0x60, 0x3e, 0xa1, 0x29, 0x9d, 0xd8, 0xb8, 0xe3, 0xfb, 0xb8, 0xb9, 0x37, 0xe7, 0xe0, 0x47, 0x77, + 0x76, 0x47, 0x28, 0x32, 0x3b, 0x13, 0xb3, 0x2d, 0x32, 0x9c, 0x00, 0x44, 0xca, 0x11, 0x22, 0xd9, + 0x5c, 0xdc, 0xcb, 0x0f, 0xc2, 0xf8, 0xe3, 0x6b, 0xbf, 0x57, 0x95, 0xc9, 0x2d, 0x6e, 0xbc, 0xa5, + 0x88, 0x21, 0x7e, 0xa3, 0x1a, 0x6f, 0xc9, 0x3d, 0x5e, 0x41, 0x4c, 0xde, 0xd0, 0x86, 0x21, 0xbe, + 0x53, 0x33, 0x4c, 0xf6, 0xac, 0x87, 0xd1, 0xd1, 0x96, 0x21, 0x7e, 0xad, 0x66, 0x20, 0xcf, 0x78, + 0x67, 0xc7, 0x34, 0x78, 0xa3, 0xc1, 0xd1, 0x2b, 0x86, 0xf8, 0x56, 0x2d, 0x82, 0x3c, 0xe1, 0x6d, + 0x76, 0xa0, 0xfd, 0xd1, 0x59, 0xba, 0xaa, 0x9f, 0x7f, 0x4c, 0xee, 0x70, 0x7b, 0x8a, 0x85, 0xae, + 0xeb, 0xd9, 0xe9, 0x39, 0xed, 0x02, 0x1f, 0x5c, 0x01, 0x1d, 0x12, 0xdd, 0x30, 0xc4, 0x5b, 0xb5, + 0x88, 0xf7, 0x4f, 0xfc, 0x50, 0x7a, 0xd1, 0x69, 0x30, 0xbd, 0x98, 0x33, 0x8a, 0x4b, 0x9e, 0xef, + 0xb7, 0x83, 0x87, 0x7e, 0xec, 0x84, 0x89, 0x41, 0xd6, 0x01, 0x13, 0x73, 0x92, 0xc5, 0xf4, 0x2e, + 0xe8, 0x22, 0xbb, 0xd1, 0x0f, 0x56, 0x1e, 0xa2, 0xfc, 0xdf, 0x4c, 0xb7, 0xae, 0xad, 0xbc, 0xfe, + 0x06, 0x00, 0x00, 0xff, 0xff, 0x2c, 0xa9, 0x20, 0x36, 0x32, 0x01, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/replay.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/replay.pb.go index 8adb2851..c35711e6 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/replay.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/replay.pb.go @@ -40,6 +40,9 @@ type Replay struct { // *Replay_Sqs // *Replay_Amqp // *Replay_Kafka + // *Replay_RedisPubsub + // *Replay_RedisStreams + // *Replay_Dynamic Dst isReplay_Dst `protobuf_oneof:"dst"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -119,6 +122,18 @@ type Replay_Kafka struct { Kafka *destinations.Kafka `protobuf:"bytes,103,opt,name=kafka,proto3,oneof"` } +type Replay_RedisPubsub struct { + RedisPubsub *destinations.RedisPubsub `protobuf:"bytes,104,opt,name=redis_pubsub,json=redisPubsub,proto3,oneof"` +} + +type Replay_RedisStreams struct { + RedisStreams *destinations.RedisStreams `protobuf:"bytes,105,opt,name=redis_streams,json=redisStreams,proto3,oneof"` +} + +type Replay_Dynamic struct { + Dynamic *destinations.Dynamic `protobuf:"bytes,106,opt,name=dynamic,proto3,oneof"` +} + func (*Replay_Http) isReplay_Dst() {} func (*Replay_Sqs) isReplay_Dst() {} @@ -127,6 +142,12 @@ func (*Replay_Amqp) isReplay_Dst() {} func (*Replay_Kafka) isReplay_Dst() {} +func (*Replay_RedisPubsub) isReplay_Dst() {} + +func (*Replay_RedisStreams) isReplay_Dst() {} + +func (*Replay_Dynamic) isReplay_Dst() {} + func (m *Replay) GetDst() isReplay_Dst { if m != nil { return m.Dst @@ -162,6 +183,27 @@ func (m *Replay) GetKafka() *destinations.Kafka { return nil } +func (m *Replay) GetRedisPubsub() *destinations.RedisPubsub { + if x, ok := m.GetDst().(*Replay_RedisPubsub); ok { + return x.RedisPubsub + } + return nil +} + +func (m *Replay) GetRedisStreams() *destinations.RedisStreams { + if x, ok := m.GetDst().(*Replay_RedisStreams); ok { + return x.RedisStreams + } + return nil +} + +func (m *Replay) GetDynamic() *destinations.Dynamic { + if x, ok := m.GetDst().(*Replay_Dynamic); ok { + return x.Dynamic + } + return nil +} + // XXX_OneofWrappers is for the internal use of the proto package. func (*Replay) XXX_OneofWrappers() []interface{} { return []interface{}{ @@ -169,6 +211,9 @@ func (*Replay) XXX_OneofWrappers() []interface{} { (*Replay_Sqs)(nil), (*Replay_Amqp)(nil), (*Replay_Kafka)(nil), + (*Replay_RedisPubsub)(nil), + (*Replay_RedisStreams)(nil), + (*Replay_Dynamic)(nil), } } @@ -179,26 +224,32 @@ func init() { func init() { proto.RegisterFile("replay.proto", fileDescriptor_eed9461330ccfc03) } var fileDescriptor_eed9461330ccfc03 = []byte{ - // 322 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x90, 0xe1, 0x6a, 0xf2, 0x30, - 0x14, 0x86, 0xb5, 0x6a, 0xc1, 0x7c, 0x22, 0xdf, 0x32, 0xd8, 0x82, 0x30, 0x90, 0xc1, 0x86, 0x30, - 0x49, 0x61, 0xbb, 0x82, 0x09, 0x1b, 0x95, 0x31, 0x98, 0xd5, 0x5f, 0xfb, 0x23, 0x69, 0x12, 0x6d, - 0xb0, 0x9a, 0xb6, 0x49, 0xc7, 0xbc, 0xb7, 0x5d, 0xdc, 0xc8, 0x69, 0x85, 0x15, 0xfc, 0x7b, 0x9e, - 0xe7, 0x9c, 0xbc, 0x79, 0xd1, 0xa0, 0x90, 0x59, 0xca, 0x8e, 0x34, 0x2b, 0xb4, 0xd5, 0xd8, 0x97, - 0x5f, 0xf2, 0x60, 0xcd, 0x68, 0xb0, 0x51, 0xa9, 0x95, 0x45, 0x35, 0x1d, 0x5d, 0x0b, 0x69, 0xac, - 0x3a, 0x30, 0xab, 0xf4, 0xc1, 0x04, 0x89, 0xb5, 0x59, 0x0d, 0xae, 0x1a, 0xc0, 0xe4, 0xe6, 0xec, - 0x02, 0xdb, 0xe7, 0xa7, 0x05, 0xd2, 0x00, 0x3b, 0xb6, 0xd9, 0xb1, 0x8a, 0xdc, 0xfe, 0x78, 0xc8, - 0x8f, 0x20, 0x0a, 0x1e, 0x22, 0x4f, 0x09, 0xd2, 0x1e, 0xb7, 0x27, 0xfd, 0xc8, 0x53, 0x02, 0xdf, - 0x23, 0xbf, 0x8a, 0x43, 0xbc, 0x71, 0x7b, 0xf2, 0xef, 0x71, 0x48, 0xab, 0x94, 0xf4, 0x15, 0xa6, - 0x51, 0x4d, 0xf1, 0x0d, 0x42, 0x5c, 0xa7, 0xa9, 0xe4, 0x76, 0xad, 0x04, 0xe9, 0xc0, 0x7e, 0xbf, - 0x9e, 0xcc, 0x05, 0x9e, 0x22, 0x9c, 0x97, 0xb2, 0x38, 0xae, 0xe5, 0xb7, 0xe4, 0xa5, 0x4b, 0xe0, - 0xb4, 0x2e, 0x68, 0xff, 0x81, 0xbc, 0x9c, 0xc0, 0x5c, 0xe0, 0x09, 0xea, 0xba, 0x8f, 0x12, 0x01, - 0x4f, 0x62, 0xfa, 0x37, 0x38, 0x0d, 0x57, 0xab, 0x8f, 0xb0, 0x15, 0x81, 0x81, 0xef, 0x50, 0xc7, - 0xe4, 0x86, 0x48, 0x10, 0x2f, 0x9a, 0xe2, 0x72, 0xb1, 0x0c, 0x5b, 0x91, 0xe3, 0xee, 0xa0, 0x2b, - 0x82, 0x6c, 0xce, 0x1d, 0x7c, 0x7e, 0x5f, 0xc0, 0x41, 0x67, 0xe0, 0x07, 0xd4, 0x83, 0x66, 0xc8, - 0x16, 0xd4, 0xcb, 0xa6, 0xfa, 0xe6, 0x50, 0xd8, 0x8a, 0x2a, 0x67, 0xd6, 0x43, 0x1d, 0x61, 0xec, - 0x8c, 0x7e, 0x4e, 0xb7, 0xca, 0x26, 0x65, 0x4c, 0xb9, 0xde, 0x07, 0x31, 0xb3, 0x3c, 0xe1, 0xba, - 0xc8, 0x02, 0xc3, 0x13, 0xb9, 0x67, 0x26, 0x88, 0x4b, 0x95, 0x8a, 0x60, 0xab, 0x83, 0xaa, 0xba, - 0xd8, 0x87, 0xd6, 0x9f, 0x7e, 0x03, 0x00, 0x00, 0xff, 0xff, 0x45, 0x19, 0x41, 0xf7, 0xff, 0x01, - 0x00, 0x00, + // 423 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x92, 0x61, 0x6b, 0x13, 0x31, + 0x18, 0xc7, 0xaf, 0xed, 0x56, 0x59, 0x36, 0x87, 0x46, 0xd4, 0x58, 0x10, 0x8b, 0xa0, 0x14, 0x9c, + 0x77, 0xa8, 0xef, 0x85, 0x0d, 0x95, 0x1b, 0x22, 0x6c, 0xe9, 0x5e, 0xf9, 0xa6, 0xe4, 0x92, 0xb4, + 0x17, 0x7b, 0xd7, 0xbb, 0x26, 0x39, 0xb1, 0x5f, 0xdb, 0x4f, 0x20, 0x79, 0x92, 0xc3, 0x05, 0xee, + 0x65, 0xf2, 0xfb, 0xfd, 0x9f, 0x24, 0xcf, 0x13, 0x74, 0xa6, 0x65, 0x5b, 0xb1, 0x43, 0xda, 0xea, + 0xc6, 0x36, 0x78, 0x2a, 0x7f, 0xcb, 0x9d, 0x35, 0xb3, 0xb3, 0xb5, 0xaa, 0xac, 0xd4, 0x7e, 0x77, + 0xf6, 0x5c, 0x48, 0x63, 0xd5, 0x8e, 0x59, 0xd5, 0xec, 0x4c, 0x56, 0x5a, 0xdb, 0x06, 0xf0, 0x2c, + 0x02, 0x66, 0x6f, 0x06, 0x03, 0xac, 0xde, 0xf7, 0x01, 0x12, 0x81, 0x2d, 0x5b, 0x6f, 0x59, 0x20, + 0xaf, 0x22, 0xa2, 0xa5, 0x50, 0xe6, 0x7d, 0xdb, 0x15, 0xa6, 0x2b, 0x82, 0x30, 0x1f, 0x10, 0x8c, + 0xd5, 0x92, 0xd5, 0xfd, 0xa9, 0xb3, 0xc8, 0x10, 0x87, 0x1d, 0xab, 0x15, 0xf7, 0xec, 0xf5, 0xdf, + 0x09, 0x9a, 0x52, 0x78, 0x29, 0x3e, 0x47, 0x63, 0x25, 0xc8, 0x68, 0x3e, 0x5a, 0x9c, 0xd0, 0xb1, + 0x12, 0xf8, 0x2d, 0x9a, 0xfa, 0xd7, 0x92, 0xf1, 0x7c, 0xb4, 0x38, 0xfd, 0x78, 0x9e, 0xfa, 0x26, + 0xa4, 0xdf, 0x60, 0x97, 0x06, 0x8a, 0x5f, 0x22, 0xc4, 0x9b, 0xaa, 0x92, 0xdc, 0xae, 0x94, 0x20, + 0x13, 0xc8, 0x9f, 0x84, 0x9d, 0x6b, 0x81, 0x2f, 0x10, 0xde, 0x77, 0x52, 0x1f, 0x56, 0xf2, 0x8f, + 0xe4, 0x9d, 0xbb, 0x83, 0xd3, 0x8e, 0x40, 0x7b, 0x04, 0xe4, 0x6b, 0x0f, 0xae, 0x05, 0x5e, 0xa0, + 0x23, 0xd7, 0x47, 0x22, 0xe0, 0x48, 0x9c, 0xde, 0xbf, 0x7a, 0x9a, 0xdf, 0xdd, 0xdd, 0xe4, 0x09, + 0x05, 0x03, 0xbf, 0x41, 0x13, 0xb3, 0x37, 0x44, 0x82, 0xf8, 0x38, 0x16, 0x97, 0xb7, 0xcb, 0x3c, + 0xa1, 0x8e, 0xbb, 0x82, 0xae, 0xcf, 0x64, 0x3d, 0x54, 0xf0, 0xf2, 0xc7, 0x2d, 0x14, 0x74, 0x06, + 0x7e, 0x87, 0x8e, 0xa1, 0xf1, 0x64, 0x03, 0xea, 0x93, 0x58, 0xfd, 0xee, 0x50, 0x9e, 0x50, 0xef, + 0xe0, 0xcf, 0xee, 0x83, 0x08, 0x65, 0x56, 0x7e, 0x16, 0xa4, 0x84, 0xcc, 0x8b, 0x38, 0x43, 0x9d, + 0x71, 0x03, 0x42, 0x9e, 0xd0, 0x53, 0xfd, 0x7f, 0x89, 0x2f, 0xd1, 0x43, 0x9f, 0x0f, 0xa3, 0x22, + 0x0a, 0x0a, 0xcc, 0x06, 0x0a, 0x2c, 0xbd, 0x91, 0x27, 0xd4, 0x1f, 0x19, 0xd6, 0xf8, 0x03, 0x7a, + 0x10, 0x66, 0x49, 0x7e, 0x41, 0xf8, 0x69, 0x1c, 0xfe, 0xe2, 0x61, 0x9e, 0xd0, 0xde, 0xbb, 0x3a, + 0x46, 0x13, 0x61, 0xec, 0x55, 0xfa, 0xf3, 0x62, 0xa3, 0x6c, 0xd9, 0x15, 0x29, 0x6f, 0xea, 0xac, + 0x60, 0x96, 0x97, 0xbc, 0xd1, 0x6d, 0x66, 0x78, 0x29, 0x6b, 0x66, 0xb2, 0xa2, 0x53, 0x95, 0xc8, + 0x36, 0x4d, 0xe6, 0x07, 0x5e, 0x4c, 0xe1, 0xaf, 0x7c, 0xfa, 0x17, 0x00, 0x00, 0xff, 0xff, 0x78, + 0x14, 0x6f, 0xb9, 0x14, 0x03, 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/schema.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/schema.pb.go index 59b12e15..83339b1d 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/schema.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/schema.pb.go @@ -51,6 +51,35 @@ func (Schema_Type) EnumDescriptor() ([]byte, []int) { return fileDescriptor_1c5fb4d8cc22d66a, []int{0, 0} } +type Schema_ElectionStatus int32 + +const ( + Schema_UNSET Schema_ElectionStatus = 0 + Schema_SUCCESS Schema_ElectionStatus = 1 + Schema_FAILED Schema_ElectionStatus = 2 +) + +var Schema_ElectionStatus_name = map[int32]string{ + 0: "UNSET", + 1: "SUCCESS", + 2: "FAILED", +} + +var Schema_ElectionStatus_value = map[string]int32{ + "UNSET": 0, + "SUCCESS": 1, + "FAILED": 2, +} + +func (x Schema_ElectionStatus) String() string { + return proto.EnumName(Schema_ElectionStatus_name, int32(x)) +} + +func (Schema_ElectionStatus) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_1c5fb4d8cc22d66a, []int{0, 1} +} + +// deprecated type Schema_UpdateType int32 const ( @@ -73,7 +102,7 @@ func (x Schema_UpdateType) String() string { } func (Schema_UpdateType) EnumDescriptor() ([]byte, []int) { - return fileDescriptor_1c5fb4d8cc22d66a, []int{0, 1} + return fileDescriptor_1c5fb4d8cc22d66a, []int{0, 2} } type Schema struct { @@ -83,18 +112,19 @@ type Schema struct { Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` // Indicates the "data type" - what format are the collectors expecting to // receive the events in? - Type Schema_Type `protobuf:"varint,2,opt,name=type,proto3,enum=events.Schema_Type" json:"type,omitempty"` - Raw map[string][]byte `protobuf:"bytes,3,rep,name=raw,proto3" json:"raw,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` + Type Schema_Type `protobuf:"varint,2,opt,name=type,proto3,enum=events.Schema_Type" json:"type,omitempty"` + // Not sure what this is used for - super vague; Mark wasn't able to find any uses + Raw map[string][]byte `protobuf:"bytes,3,rep,name=raw,proto3" json:"raw,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` // Deprecated: Do not use. // Only used when Type == PROTOBUF ProtobufMessageName string `protobuf:"bytes,4,opt,name=protobuf_message_name,json=protobufMessageName,proto3" json:"protobuf_message_name,omitempty"` ProtobufFileDescriptorSet []byte `protobuf:"bytes,5,opt,name=protobuf_file_descriptor_set,json=protobufFileDescriptorSet,proto3" json:"protobuf_file_descriptor_set,omitempty"` // The following fields are used by the schema-manager to facilitate schema updates UpdateType Schema_UpdateType `protobuf:"varint,6,opt,name=update_type,json=updateType,proto3,enum=events.Schema_UpdateType" json:"update_type,omitempty"` // Deprecated: Do not use. - UpdateCollectToken string `protobuf:"bytes,7,opt,name=update_collect_token,json=updateCollectToken,proto3" json:"update_collect_token,omitempty"` - UpdateParquetSchema []byte `protobuf:"bytes,8,opt,name=update_parquet_schema,json=updateParquetSchema,proto3" json:"update_parquet_schema,omitempty"` - UpdateSqlSchema []byte `protobuf:"bytes,9,opt,name=update_sql_schema,json=updateSqlSchema,proto3" json:"update_sql_schema,omitempty"` // Deprecated: Do not use. - UpdateFingerprint string `protobuf:"bytes,10,opt,name=update_fingerprint,json=updateFingerprint,proto3" json:"update_fingerprint,omitempty"` // Deprecated: Do not use. - UpdateCollectId string `protobuf:"bytes,11,opt,name=update_collect_id,json=updateCollectId,proto3" json:"update_collect_id,omitempty"` + UpdateCollectToken string `protobuf:"bytes,7,opt,name=update_collect_token,json=updateCollectToken,proto3" json:"update_collect_token,omitempty"` // Deprecated: Do not use. + UpdateParquetSchema []byte `protobuf:"bytes,8,opt,name=update_parquet_schema,json=updateParquetSchema,proto3" json:"update_parquet_schema,omitempty"` // Deprecated: Do not use. + UpdateSqlSchema []byte `protobuf:"bytes,9,opt,name=update_sql_schema,json=updateSqlSchema,proto3" json:"update_sql_schema,omitempty"` // Deprecated: Do not use. + UpdateFingerprint string `protobuf:"bytes,10,opt,name=update_fingerprint,json=updateFingerprint,proto3" json:"update_fingerprint,omitempty"` // Deprecated: Do not use. + UpdateCollectId string `protobuf:"bytes,11,opt,name=update_collect_id,json=updateCollectId,proto3" json:"update_collect_id,omitempty"` // Deprecated: Do not use. // Schema version is used to create unique collect-update-* topics which in // turn allow the writer to write data using correct schema when there are // more than 1 schema updates in-flight. Talk to MG or DS. @@ -103,10 +133,36 @@ type Schema struct { SchemaVersion int64 `protobuf:"varint,12,opt,name=schema_version,json=schemaVersion,proto3" json:"schema_version,omitempty"` // Deprecated: Do not use. // The manifest message payload, as JSON, to infer the schema from. // Only used when Message.Type == GENERATE_SCHEMA - SourcePayload []byte `protobuf:"bytes,13,opt,name=source_payload,json=sourcePayload,proto3" json:"source_payload,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` + SourcePayload []byte `protobuf:"bytes,13,opt,name=source_payload,json=sourcePayload,proto3" json:"source_payload,omitempty"` // Deprecated: Do not use. + // A single election can reference multiple batches - this ID represents + // this specific election event. Set by athena-writer, used by schema-manager + // for the etcd key under /schema-manager/elections/$collection_id/<$election_id> + ElectionId string `protobuf:"bytes,99,opt,name=election_id,json=electionId,proto3" json:"election_id,omitempty"` + // What collection this schema message pertains to + ElectionCollectionId string `protobuf:"bytes,100,opt,name=election_collection_id,json=electionCollectionId,proto3" json:"election_collection_id,omitempty"` + // Indicates the status of a completed election; set by schema-manager + ElectionStatus Schema_ElectionStatus `protobuf:"varint,101,opt,name=election_status,json=electionStatus,proto3,enum=events.Schema_ElectionStatus" json:"election_status,omitempty"` + // In case of election failure, this field explains what happened + ElectionStatusMessage string `protobuf:"bytes,102,opt,name=election_status_message,json=electionStatusMessage,proto3" json:"election_status_message,omitempty"` + // Which batches this election pertains to. + // Every athena-writer assigns a unique batch-id for the batch they are + // working on/electing. If a STATUS_ELECT_SCHEMA comes in, athena-writer + // needs to check that the STATUS_ELECT_SCHEMA pertains to both the + // collection_id AND batch id before it uses the elected schema. If the + // batch id is not found, then their ELECT_SCHEMA probably pertains to + // another election (and should continue waiting for another + // STATUS_ELECT_SCHEMA message). + // + // This field is used by both - athena-writer and schema-manager: + // + // athena-writer uses it to specify what batch this ELECT_SCHEMA pertains to + // schema-manager uses it to indicate which batches an STATUS_ELECT_SCHEMA pertains to + ElectionBatchIds []string `protobuf:"bytes,103,rep,name=election_batch_ids,json=electionBatchIds,proto3" json:"election_batch_ids,omitempty"` + // Set by athena-writer IF schema election succeeded + ElectionParquetSchema []byte `protobuf:"bytes,104,opt,name=election_parquet_schema,json=electionParquetSchema,proto3" json:"election_parquet_schema,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` } func (m *Schema) Reset() { *m = Schema{} } @@ -148,6 +204,7 @@ func (m *Schema) GetType() Schema_Type { return Schema_UNKNOWN } +// Deprecated: Do not use. func (m *Schema) GetRaw() map[string][]byte { if m != nil { return m.Raw @@ -177,6 +234,7 @@ func (m *Schema) GetUpdateType() Schema_UpdateType { return Schema_INITIAL } +// Deprecated: Do not use. func (m *Schema) GetUpdateCollectToken() string { if m != nil { return m.UpdateCollectToken @@ -184,6 +242,7 @@ func (m *Schema) GetUpdateCollectToken() string { return "" } +// Deprecated: Do not use. func (m *Schema) GetUpdateParquetSchema() []byte { if m != nil { return m.UpdateParquetSchema @@ -207,6 +266,7 @@ func (m *Schema) GetUpdateFingerprint() string { return "" } +// Deprecated: Do not use. func (m *Schema) GetUpdateCollectId() string { if m != nil { return m.UpdateCollectId @@ -222,6 +282,7 @@ func (m *Schema) GetSchemaVersion() int64 { return 0 } +// Deprecated: Do not use. func (m *Schema) GetSourcePayload() []byte { if m != nil { return m.SourcePayload @@ -229,8 +290,51 @@ func (m *Schema) GetSourcePayload() []byte { return nil } +func (m *Schema) GetElectionId() string { + if m != nil { + return m.ElectionId + } + return "" +} + +func (m *Schema) GetElectionCollectionId() string { + if m != nil { + return m.ElectionCollectionId + } + return "" +} + +func (m *Schema) GetElectionStatus() Schema_ElectionStatus { + if m != nil { + return m.ElectionStatus + } + return Schema_UNSET +} + +func (m *Schema) GetElectionStatusMessage() string { + if m != nil { + return m.ElectionStatusMessage + } + return "" +} + +func (m *Schema) GetElectionBatchIds() []string { + if m != nil { + return m.ElectionBatchIds + } + return nil +} + +func (m *Schema) GetElectionParquetSchema() []byte { + if m != nil { + return m.ElectionParquetSchema + } + return nil +} + func init() { proto.RegisterEnum("events.Schema_Type", Schema_Type_name, Schema_Type_value) + proto.RegisterEnum("events.Schema_ElectionStatus", Schema_ElectionStatus_name, Schema_ElectionStatus_value) proto.RegisterEnum("events.Schema_UpdateType", Schema_UpdateType_name, Schema_UpdateType_value) proto.RegisterType((*Schema)(nil), "events.Schema") proto.RegisterMapType((map[string][]byte)(nil), "events.Schema.RawEntry") @@ -239,39 +343,48 @@ func init() { func init() { proto.RegisterFile("schema.proto", fileDescriptor_1c5fb4d8cc22d66a) } var fileDescriptor_1c5fb4d8cc22d66a = []byte{ - // 538 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x5c, 0x92, 0x5f, 0x6f, 0xd3, 0x30, - 0x14, 0xc5, 0x97, 0xa4, 0xeb, 0xda, 0xdb, 0x3f, 0x0b, 0xee, 0x10, 0x1e, 0xe2, 0xa1, 0xaa, 0x84, - 0xd6, 0x21, 0x94, 0x42, 0x91, 0x26, 0xc4, 0x03, 0x68, 0x85, 0x15, 0x05, 0x46, 0x5a, 0xa5, 0x2d, - 0x20, 0x5e, 0xa2, 0x34, 0x71, 0x5b, 0x6b, 0x69, 0x9c, 0x3a, 0x4e, 0xa7, 0x3e, 0xf2, 0xcd, 0x51, - 0xec, 0xb4, 0x13, 0x7b, 0xb3, 0xfd, 0x3b, 0xc7, 0xf7, 0x1e, 0xfb, 0x42, 0x3d, 0x0d, 0x56, 0x64, - 0xed, 0x5b, 0x09, 0x67, 0x82, 0xa1, 0x32, 0xd9, 0x92, 0x58, 0xa4, 0x9d, 0xbf, 0x65, 0x28, 0x4f, - 0x24, 0x40, 0x4d, 0xd0, 0x69, 0x88, 0xb5, 0xb6, 0xd6, 0xad, 0xba, 0x3a, 0x0d, 0xd1, 0x05, 0x94, - 0xc4, 0x2e, 0x21, 0x58, 0x6f, 0x6b, 0xdd, 0x66, 0xbf, 0x65, 0x29, 0x87, 0xa5, 0xd4, 0xd6, 0x74, - 0x97, 0x10, 0x57, 0x0a, 0xd0, 0x25, 0x18, 0xdc, 0xbf, 0xc7, 0x46, 0xdb, 0xe8, 0xd6, 0xfa, 0xcf, - 0x1e, 0xe9, 0x5c, 0xff, 0xfe, 0x26, 0x16, 0x7c, 0xe7, 0xe6, 0x1a, 0xd4, 0x87, 0xa7, 0xb2, 0xfe, - 0x3c, 0x5b, 0x78, 0x6b, 0x92, 0xa6, 0xfe, 0x92, 0x78, 0xb1, 0xbf, 0x26, 0xb8, 0x24, 0xcb, 0xb6, - 0xf6, 0xf0, 0x87, 0x62, 0x8e, 0xbf, 0x26, 0xe8, 0x13, 0xbc, 0x38, 0x78, 0x16, 0x34, 0x22, 0x5e, - 0x48, 0xd2, 0x80, 0xd3, 0x44, 0x30, 0xee, 0xa5, 0x44, 0xe0, 0xe3, 0xb6, 0xd6, 0xad, 0xbb, 0xe7, - 0x7b, 0xcd, 0x90, 0x46, 0xe4, 0xcb, 0x41, 0x31, 0x21, 0x02, 0x7d, 0x84, 0x5a, 0x96, 0x84, 0xbe, - 0x20, 0x9e, 0xcc, 0x53, 0x96, 0x79, 0xce, 0x1f, 0xf5, 0x39, 0x93, 0x8a, 0x3c, 0xd5, 0x40, 0xc7, - 0x9a, 0x0b, 0xd9, 0x61, 0x8f, 0xde, 0xc0, 0x59, 0xe1, 0x0f, 0x58, 0x14, 0x91, 0x40, 0x78, 0x82, - 0xdd, 0x91, 0x18, 0x9f, 0xc8, 0x9e, 0x91, 0x62, 0x9f, 0x15, 0x9a, 0xe6, 0x24, 0x8f, 0x59, 0x38, - 0x12, 0x9f, 0x6f, 0x32, 0x22, 0x3c, 0xf5, 0xf8, 0xb8, 0x22, 0x7b, 0x6d, 0x29, 0x38, 0x56, 0xac, - 0x78, 0x7e, 0x0b, 0x9e, 0x14, 0x9e, 0x74, 0x13, 0xed, 0xf5, 0xd5, 0x5c, 0x2f, 0x1b, 0x3a, 0x55, - 0x70, 0xb2, 0x89, 0x0a, 0xfd, 0x5b, 0x28, 0x2a, 0x7b, 0x0b, 0x1a, 0x2f, 0x09, 0x4f, 0x38, 0x8d, - 0x05, 0x86, 0xbc, 0x27, 0x69, 0x28, 0x6e, 0x1b, 0x3e, 0x40, 0xf4, 0xea, 0x50, 0x62, 0x1f, 0x84, - 0x86, 0xb8, 0x26, 0x53, 0x9c, 0xfe, 0x97, 0xc2, 0x0e, 0xd1, 0x25, 0x34, 0x55, 0x0f, 0xde, 0x96, - 0xf0, 0x94, 0xb2, 0x18, 0xd7, 0xdb, 0x5a, 0xd7, 0x90, 0x57, 0x37, 0x14, 0xf9, 0xa9, 0x00, 0x7a, - 0x09, 0xcd, 0x94, 0x65, 0x3c, 0xc8, 0xd3, 0xee, 0x22, 0xe6, 0x87, 0xb8, 0x21, 0x63, 0x36, 0xd4, - 0xe9, 0x58, 0x1d, 0x3e, 0xbf, 0x82, 0xca, 0x7e, 0x18, 0x90, 0x09, 0xc6, 0x1d, 0xd9, 0x15, 0xc3, - 0x96, 0x2f, 0xd1, 0x19, 0x1c, 0x6f, 0xfd, 0x28, 0x53, 0xe3, 0x56, 0x77, 0xd5, 0xe6, 0x83, 0xfe, - 0x5e, 0xeb, 0x5c, 0x41, 0x49, 0x7e, 0x43, 0x0d, 0x4e, 0x66, 0xce, 0x77, 0x67, 0xf4, 0xcb, 0x31, - 0x8f, 0x50, 0x15, 0x8e, 0xc7, 0xb7, 0xd7, 0xb6, 0x63, 0x6a, 0xa8, 0x02, 0xa5, 0x6f, 0x93, 0x91, - 0x63, 0xea, 0xa8, 0x0e, 0x95, 0xb1, 0x3b, 0x9a, 0x8e, 0x06, 0xb3, 0xa1, 0x69, 0x74, 0x2e, 0x00, - 0x1e, 0x3e, 0x35, 0x77, 0xdb, 0x8e, 0x3d, 0xb5, 0xaf, 0x6f, 0xcd, 0xa3, 0x5c, 0x78, 0xf3, 0xdb, - 0x9e, 0x4c, 0x6d, 0xe7, 0xab, 0xa9, 0x0d, 0xac, 0x3f, 0xaf, 0x97, 0x54, 0xac, 0xb2, 0xb9, 0x15, - 0xb0, 0x75, 0x6f, 0xee, 0x8b, 0x60, 0x15, 0x30, 0x9e, 0xf4, 0x54, 0xca, 0xb4, 0x37, 0xcf, 0x68, - 0x14, 0xf6, 0x96, 0xac, 0xa7, 0x26, 0x66, 0x5e, 0x96, 0xa3, 0xf6, 0xee, 0x5f, 0x00, 0x00, 0x00, - 0xff, 0xff, 0xb6, 0x75, 0x8e, 0xb9, 0x52, 0x03, 0x00, 0x00, + // 679 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x5c, 0x93, 0x41, 0x6f, 0xda, 0x4c, + 0x10, 0x86, 0x63, 0x4c, 0x08, 0x0c, 0x84, 0xf8, 0xdb, 0x24, 0x5f, 0x36, 0x55, 0xab, 0x22, 0x2e, + 0xa1, 0x52, 0x6a, 0xd4, 0x34, 0x42, 0x55, 0x0f, 0xad, 0x02, 0x81, 0xca, 0x6d, 0x6a, 0x90, 0x0d, + 0x6d, 0xd5, 0x8b, 0x65, 0xec, 0x05, 0xac, 0x18, 0xdb, 0xb1, 0xd7, 0x89, 0xf8, 0x07, 0xfd, 0xd9, + 0xd5, 0xee, 0xda, 0x4e, 0xe1, 0xe6, 0xf5, 0xfb, 0xbc, 0x3b, 0x33, 0x3b, 0x33, 0xd0, 0x48, 0x9c, + 0x15, 0x59, 0xdb, 0x6a, 0x14, 0x87, 0x34, 0x44, 0x15, 0xf2, 0x48, 0x02, 0x9a, 0xb4, 0xff, 0xd4, + 0xa0, 0x62, 0x72, 0x01, 0x35, 0xa1, 0xe4, 0xb9, 0x58, 0x6a, 0x49, 0x9d, 0x9a, 0x51, 0xf2, 0x5c, + 0x74, 0x01, 0x65, 0xba, 0x89, 0x08, 0x2e, 0xb5, 0xa4, 0x4e, 0xf3, 0xea, 0x58, 0x15, 0x0e, 0x55, + 0xd0, 0xea, 0x74, 0x13, 0x11, 0x83, 0x03, 0xe8, 0x2d, 0xc8, 0xb1, 0xfd, 0x84, 0xe5, 0x96, 0xdc, + 0xa9, 0x5f, 0x9d, 0xed, 0x70, 0x86, 0xfd, 0x34, 0x0c, 0x68, 0xbc, 0xe9, 0x97, 0xb0, 0x64, 0x30, + 0x0e, 0x5d, 0xc1, 0x29, 0xcf, 0x61, 0x9e, 0x2e, 0xac, 0x35, 0x49, 0x12, 0x7b, 0x49, 0xac, 0xc0, + 0x5e, 0x13, 0x5c, 0xe6, 0xa1, 0x8f, 0x73, 0xf1, 0xbb, 0xd0, 0x74, 0x7b, 0x4d, 0xd0, 0x67, 0x78, + 0x59, 0x78, 0x16, 0x9e, 0x4f, 0x2c, 0x97, 0x24, 0x4e, 0xec, 0x45, 0x34, 0x8c, 0xad, 0x84, 0x50, + 0xbc, 0xdf, 0x92, 0x3a, 0x0d, 0xe3, 0x3c, 0x67, 0x46, 0x9e, 0x4f, 0x6e, 0x0b, 0xc2, 0x24, 0x14, + 0x7d, 0x82, 0x7a, 0x1a, 0xb9, 0x36, 0x25, 0x16, 0xaf, 0xa9, 0xc2, 0x6b, 0x3a, 0xdf, 0xc9, 0x75, + 0xc6, 0x09, 0x56, 0x19, 0xcf, 0x16, 0xd2, 0xe2, 0x8c, 0xae, 0xe1, 0x24, 0xf3, 0x3b, 0xa1, 0xef, + 0x13, 0x87, 0x5a, 0x34, 0xbc, 0x27, 0x01, 0x3e, 0x60, 0x39, 0x73, 0x1a, 0x09, 0x7d, 0x20, 0xe4, + 0x29, 0x53, 0x51, 0x0f, 0x4e, 0x33, 0x57, 0x64, 0xc7, 0x0f, 0x29, 0xa1, 0x96, 0x68, 0x02, 0xae, + 0xb2, 0x7c, 0xb9, 0xed, 0x58, 0x00, 0x13, 0xa1, 0x67, 0xad, 0x50, 0xe1, 0xbf, 0xcc, 0x97, 0x3c, + 0xf8, 0xb9, 0xa7, 0x56, 0x78, 0x8e, 0x84, 0x68, 0x3e, 0xf8, 0x19, 0xff, 0x0e, 0xb2, 0xe8, 0xd6, + 0xc2, 0x0b, 0x96, 0x24, 0x8e, 0x62, 0x2f, 0xa0, 0x18, 0x8a, 0xdc, 0xb2, 0xdb, 0x46, 0xcf, 0xe2, + 0x3f, 0x21, 0xf2, 0x82, 0x3c, 0x17, 0xd7, 0x0b, 0xc7, 0xd1, 0x56, 0x35, 0x9a, 0x8b, 0xde, 0x40, + 0x53, 0xe4, 0x61, 0x3d, 0x92, 0x38, 0xf1, 0xc2, 0x00, 0x37, 0x5a, 0x52, 0x47, 0xe6, 0xf0, 0xa1, + 0x50, 0x7e, 0x08, 0x81, 0xa3, 0x61, 0x1a, 0x3b, 0xac, 0xea, 0x8d, 0x1f, 0xda, 0x2e, 0x3e, 0x2c, + 0x52, 0x3f, 0x14, 0xca, 0x44, 0x08, 0xe8, 0x35, 0xd4, 0x09, 0x0b, 0xe0, 0x85, 0x01, 0x8b, 0xef, + 0xf0, 0x09, 0x80, 0xfc, 0x97, 0xe6, 0xa2, 0x6b, 0xf8, 0xbf, 0x00, 0xb2, 0x44, 0x33, 0xd6, 0xe5, + 0xec, 0x49, 0xae, 0x0e, 0x0a, 0x51, 0x73, 0xd1, 0x08, 0x8e, 0x0a, 0x57, 0x42, 0x6d, 0x9a, 0x26, + 0x98, 0xf0, 0x8e, 0xbf, 0xda, 0xe9, 0xf8, 0x30, 0xa3, 0x4c, 0x0e, 0x19, 0x4d, 0xb2, 0x75, 0x46, + 0x3d, 0x38, 0xdb, 0xb9, 0x27, 0x9f, 0x58, 0xbc, 0xe0, 0xe1, 0x4f, 0xb7, 0x0d, 0xd9, 0xc8, 0xa2, + 0x4b, 0x40, 0x85, 0x6f, 0x6e, 0x53, 0x67, 0x65, 0x79, 0x6e, 0x82, 0x97, 0x2d, 0xb9, 0x53, 0x33, + 0x94, 0x5c, 0xe9, 0x33, 0x41, 0x73, 0xb7, 0xa3, 0xec, 0xcc, 0xc9, 0x8a, 0xcf, 0x75, 0x11, 0x65, + 0x6b, 0x4a, 0x5e, 0xf4, 0xa0, 0x9a, 0x6f, 0x17, 0x52, 0x40, 0xbe, 0x27, 0x9b, 0x6c, 0x7b, 0xd9, + 0x27, 0x3a, 0x81, 0xfd, 0x47, 0xdb, 0x4f, 0xc5, 0xfe, 0x36, 0x0c, 0x71, 0xf8, 0x58, 0xfa, 0x20, + 0xb5, 0x7b, 0x50, 0xe6, 0x33, 0x5d, 0x87, 0x83, 0x99, 0xfe, 0x4d, 0x1f, 0xff, 0xd4, 0x95, 0x3d, + 0x54, 0x83, 0xfd, 0xc9, 0xdd, 0x8d, 0xa6, 0x2b, 0x12, 0xaa, 0x42, 0xf9, 0xab, 0x39, 0xd6, 0x95, + 0x12, 0x6a, 0x40, 0x75, 0x62, 0x8c, 0xa7, 0xe3, 0xfe, 0x6c, 0xa4, 0xc8, 0xed, 0x6b, 0x68, 0x6e, + 0xbf, 0x17, 0x33, 0xcd, 0x74, 0x73, 0x38, 0x55, 0xf6, 0xd8, 0x65, 0xe6, 0x6c, 0x30, 0x18, 0x9a, + 0xa6, 0x22, 0x21, 0x80, 0xca, 0xe8, 0x46, 0xbb, 0x1b, 0xde, 0x2a, 0xa5, 0xf6, 0x05, 0xc0, 0xf3, + 0x5e, 0x31, 0x4c, 0xd3, 0xb5, 0xa9, 0x76, 0x73, 0xa7, 0xec, 0xb1, 0xeb, 0x87, 0xbf, 0x34, 0x73, + 0xaa, 0xe9, 0x5f, 0x14, 0xa9, 0xaf, 0xfe, 0xbe, 0x5c, 0x7a, 0x74, 0x95, 0xce, 0x55, 0x27, 0x5c, + 0x77, 0xf9, 0xb3, 0x39, 0x61, 0x1c, 0x75, 0xc5, 0x53, 0x24, 0xdd, 0x79, 0xea, 0xf9, 0x6e, 0x77, + 0x19, 0x76, 0x45, 0x0b, 0xe7, 0x15, 0xbe, 0xed, 0xef, 0xff, 0x06, 0x00, 0x00, 0xff, 0xff, 0xa9, + 0x12, 0x64, 0xbf, 0xd9, 0x04, 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/source.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/source.pb.go new file mode 100644 index 00000000..b5f2e954 --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/events/source.pb.go @@ -0,0 +1,184 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: source.proto + +package events + +import ( + fmt "fmt" + proto "github.com/golang/protobuf/proto" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type Source_Type int32 + +const ( + Source_UNSET Source_Type = 0 + Source_PLUMBER Source_Type = 1 +) + +var Source_Type_name = map[int32]string{ + 0: "UNSET", + 1: "PLUMBER", +} + +var Source_Type_value = map[string]int32{ + "UNSET": 0, + "PLUMBER": 1, +} + +func (x Source_Type) String() string { + return proto.EnumName(Source_Type_name, int32(x)) +} + +func (Source_Type) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_9229c9b6eb8e6b85, []int{0, 0} +} + +type Source struct { + // Type of source that this is. Only plumber for now + Type Source_Type `protobuf:"varint,1,opt,name=type,proto3,enum=events.Source_Type" json:"type,omitempty"` + Id string `protobuf:"bytes,2,opt,name=id,proto3" json:"id,omitempty"` + // Friendly name of the hosted plumber instance + Name string `protobuf:"bytes,3,opt,name=name,proto3" json:"name,omitempty"` + // Team that the instance belongs to + TeamId string `protobuf:"bytes,4,opt,name=team_id,json=teamId,proto3" json:"team_id,omitempty"` + // Collection ID that this source is relaying to + CollectionId string `protobuf:"bytes,5,opt,name=collection_id,json=collectionId,proto3" json:"collection_id,omitempty"` + // Number of containers to launch. Some sources, such as CDC, might only support one plumber instance + // while others can be as many as needed + InstanceCount int32 `protobuf:"varint,6,opt,name=instance_count,json=instanceCount,proto3" json:"instance_count,omitempty"` + // Flags and features may change in plumber, so we need to be sure we're always + // launching the correct docker image version on RESUME_SOURCE + PlumberVersion string `protobuf:"bytes,7,opt,name=plumber_version,json=plumberVersion,proto3" json:"plumber_version,omitempty"` + // Map of ENVAR -> Value for plumber relay flags + PlumberArgs map[string]string `protobuf:"bytes,8,rep,name=plumber_args,json=plumberArgs,proto3" json:"plumber_args,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *Source) Reset() { *m = Source{} } +func (m *Source) String() string { return proto.CompactTextString(m) } +func (*Source) ProtoMessage() {} +func (*Source) Descriptor() ([]byte, []int) { + return fileDescriptor_9229c9b6eb8e6b85, []int{0} +} + +func (m *Source) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_Source.Unmarshal(m, b) +} +func (m *Source) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_Source.Marshal(b, m, deterministic) +} +func (m *Source) XXX_Merge(src proto.Message) { + xxx_messageInfo_Source.Merge(m, src) +} +func (m *Source) XXX_Size() int { + return xxx_messageInfo_Source.Size(m) +} +func (m *Source) XXX_DiscardUnknown() { + xxx_messageInfo_Source.DiscardUnknown(m) +} + +var xxx_messageInfo_Source proto.InternalMessageInfo + +func (m *Source) GetType() Source_Type { + if m != nil { + return m.Type + } + return Source_UNSET +} + +func (m *Source) GetId() string { + if m != nil { + return m.Id + } + return "" +} + +func (m *Source) GetName() string { + if m != nil { + return m.Name + } + return "" +} + +func (m *Source) GetTeamId() string { + if m != nil { + return m.TeamId + } + return "" +} + +func (m *Source) GetCollectionId() string { + if m != nil { + return m.CollectionId + } + return "" +} + +func (m *Source) GetInstanceCount() int32 { + if m != nil { + return m.InstanceCount + } + return 0 +} + +func (m *Source) GetPlumberVersion() string { + if m != nil { + return m.PlumberVersion + } + return "" +} + +func (m *Source) GetPlumberArgs() map[string]string { + if m != nil { + return m.PlumberArgs + } + return nil +} + +func init() { + proto.RegisterEnum("events.Source_Type", Source_Type_name, Source_Type_value) + proto.RegisterType((*Source)(nil), "events.Source") + proto.RegisterMapType((map[string]string)(nil), "events.Source.PlumberArgsEntry") +} + +func init() { proto.RegisterFile("source.proto", fileDescriptor_9229c9b6eb8e6b85) } + +var fileDescriptor_9229c9b6eb8e6b85 = []byte{ + // 348 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x5c, 0x91, 0xcd, 0x8a, 0xdb, 0x30, + 0x14, 0x85, 0xeb, 0xdf, 0x34, 0x37, 0x89, 0x6b, 0xd4, 0x42, 0x4d, 0x17, 0xad, 0x49, 0x29, 0xf1, + 0xa2, 0xd8, 0x90, 0x6e, 0x4a, 0x17, 0x85, 0xa6, 0x64, 0x11, 0x68, 0x87, 0xe0, 0x24, 0xb3, 0x98, + 0x4d, 0xb0, 0x65, 0xe1, 0x88, 0xb1, 0x25, 0x23, 0xc9, 0x01, 0x3f, 0xc1, 0xbc, 0xf6, 0x60, 0x39, + 0x21, 0x90, 0xdd, 0xbd, 0xdf, 0xf9, 0x10, 0xd2, 0x11, 0x4c, 0x25, 0x6f, 0x05, 0x26, 0x71, 0x23, + 0xb8, 0xe2, 0xc8, 0x25, 0x67, 0xc2, 0x94, 0x9c, 0xbf, 0x58, 0xe0, 0xee, 0x74, 0x80, 0x16, 0x60, + 0xab, 0xae, 0x21, 0x81, 0x11, 0x1a, 0x91, 0xb7, 0x7c, 0x1f, 0x0f, 0x46, 0x3c, 0xa4, 0xf1, 0xbe, + 0x6b, 0x48, 0xaa, 0x05, 0xe4, 0x81, 0x49, 0x8b, 0xc0, 0x0c, 0x8d, 0x68, 0x9c, 0x9a, 0xb4, 0x40, + 0x08, 0x6c, 0x96, 0xd5, 0x24, 0xb0, 0x34, 0xd1, 0x33, 0xfa, 0x08, 0x23, 0x45, 0xb2, 0xfa, 0x48, + 0x8b, 0xc0, 0xd6, 0xd8, 0xed, 0xd7, 0x4d, 0x81, 0xbe, 0xc2, 0x0c, 0xf3, 0xaa, 0x22, 0x58, 0x51, + 0xce, 0xfa, 0xd8, 0xd1, 0xf1, 0xf4, 0x06, 0x37, 0x05, 0xfa, 0x06, 0x1e, 0x65, 0x52, 0x65, 0x0c, + 0x93, 0x23, 0xe6, 0x2d, 0x53, 0x81, 0x1b, 0x1a, 0x91, 0x93, 0xce, 0xae, 0xf4, 0x6f, 0x0f, 0xd1, + 0x02, 0xde, 0x35, 0x55, 0x5b, 0xe7, 0x44, 0x1c, 0xcf, 0x44, 0x48, 0xca, 0x59, 0x30, 0xd2, 0xa7, + 0x79, 0x17, 0xfc, 0x38, 0x50, 0xb4, 0x82, 0xe9, 0x55, 0xcc, 0x44, 0x29, 0x83, 0xb7, 0xa1, 0x15, + 0x4d, 0x96, 0x5f, 0xee, 0x9e, 0xb8, 0x1d, 0x94, 0x3f, 0xa2, 0x94, 0x6b, 0xa6, 0x44, 0x97, 0x4e, + 0x9a, 0x1b, 0xf9, 0xf4, 0x1b, 0xfc, 0x7b, 0x01, 0xf9, 0x60, 0x3d, 0x93, 0x4e, 0x37, 0x36, 0x4e, + 0xfb, 0x11, 0x7d, 0x00, 0xe7, 0x9c, 0x55, 0x2d, 0xb9, 0xd4, 0x33, 0x2c, 0xbf, 0xcc, 0x9f, 0xc6, + 0xfc, 0x33, 0xd8, 0x7d, 0x87, 0x68, 0x0c, 0xce, 0xe1, 0x61, 0xb7, 0xde, 0xfb, 0x6f, 0xd0, 0x04, + 0x46, 0xdb, 0x7f, 0x87, 0xff, 0xab, 0x75, 0xea, 0x1b, 0xab, 0xf8, 0xe9, 0x7b, 0x49, 0xd5, 0xa9, + 0xcd, 0x63, 0xcc, 0xeb, 0x24, 0xcf, 0x14, 0x3e, 0x61, 0x2e, 0x9a, 0x44, 0xe2, 0x13, 0xa9, 0x33, + 0x99, 0xe4, 0x2d, 0xad, 0x8a, 0xa4, 0xe4, 0xc9, 0x70, 0xe9, 0xdc, 0xd5, 0x1f, 0xf9, 0xe3, 0x35, + 0x00, 0x00, 0xff, 0xff, 0xfa, 0x23, 0x4c, 0x9b, 0xd8, 0x01, 0x00, 0x00, +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/events/tasks/zipfile.pb.go b/vendor/github.com/batchcorp/schemas/build/go/events/tasks/zipfile.pb.go index fa7f5254..85371de3 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/events/tasks/zipfile.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/events/tasks/zipfile.pb.go @@ -21,12 +21,14 @@ var _ = math.Inf const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package type Zipfile struct { + // Collection to be searched CollectionId string `protobuf:"bytes,1,opt,name=collection_id,json=collectionId,proto3" json:"collection_id,omitempty"` - Filter string `protobuf:"bytes,2,opt,name=filter,proto3" json:"filter,omitempty"` - From int32 `protobuf:"varint,3,opt,name=from,proto3" json:"from,omitempty"` - Size int32 `protobuf:"varint,4,opt,name=size,proto3" json:"size,omitempty"` - // Set by search service - Url string `protobuf:"bytes,5,opt,name=url,proto3" json:"url,omitempty"` + // Lucene query. This will be translated by the search service + Query string `protobuf:"bytes,2,opt,name=query,proto3" json:"query,omitempty"` + // ID of the query. Set by the search service. Used to get results from a finished query + QueryExecutionId string `protobuf:"bytes,3,opt,name=query_execution_id,json=queryExecutionId,proto3" json:"query_execution_id,omitempty"` + // Link to the ZIP file of the results. Set by search service + Url string `protobuf:"bytes,4,opt,name=url,proto3" json:"url,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` @@ -64,25 +66,18 @@ func (m *Zipfile) GetCollectionId() string { return "" } -func (m *Zipfile) GetFilter() string { +func (m *Zipfile) GetQuery() string { if m != nil { - return m.Filter + return m.Query } return "" } -func (m *Zipfile) GetFrom() int32 { +func (m *Zipfile) GetQueryExecutionId() string { if m != nil { - return m.From + return m.QueryExecutionId } - return 0 -} - -func (m *Zipfile) GetSize() int32 { - if m != nil { - return m.Size - } - return 0 + return "" } func (m *Zipfile) GetUrl() string { @@ -99,18 +94,18 @@ func init() { func init() { proto.RegisterFile("events/tasks/zipfile.proto", fileDescriptor_f140f00badd300ed) } var fileDescriptor_f140f00badd300ed = []byte{ - // 197 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x4c, 0x8f, 0x3f, 0x6f, 0x83, 0x30, - 0x10, 0x47, 0xe5, 0xf2, 0xa7, 0xaa, 0xd5, 0x4a, 0x95, 0x87, 0xca, 0xea, 0x84, 0xda, 0x85, 0x09, - 0x4b, 0x49, 0x3e, 0x41, 0xb6, 0xac, 0x8c, 0x2c, 0x11, 0x36, 0x06, 0x4e, 0x31, 0x1c, 0xb2, 0x4d, - 0x06, 0xa6, 0x7c, 0xf4, 0x08, 0x13, 0x29, 0xd9, 0xde, 0xbd, 0x9f, 0x6e, 0x78, 0xf4, 0x57, 0x5f, - 0xf5, 0xe8, 0x9d, 0xf0, 0xb5, 0xbb, 0x38, 0xb1, 0xc0, 0xd4, 0x82, 0xd1, 0xc5, 0x64, 0xd1, 0x23, - 0x4b, 0x82, 0xfc, 0xbb, 0x11, 0xfa, 0x5e, 0x6d, 0x03, 0xfb, 0xa7, 0x5f, 0x0a, 0x8d, 0xd1, 0xca, - 0x03, 0x8e, 0x67, 0x68, 0x38, 0xc9, 0x48, 0xfe, 0x51, 0x7e, 0x3e, 0xe5, 0xa9, 0x61, 0x3f, 0x34, - 0x6d, 0xc1, 0x78, 0x6d, 0xf9, 0x5b, 0x58, 0x1f, 0x17, 0x63, 0x34, 0x6e, 0x2d, 0x0e, 0x3c, 0xca, - 0x48, 0x9e, 0x94, 0x81, 0x57, 0xe7, 0x60, 0xd1, 0x3c, 0xde, 0xdc, 0xca, 0xec, 0x9b, 0x46, 0xb3, - 0x35, 0x3c, 0x09, 0xcf, 0x2b, 0x1e, 0x0f, 0xd5, 0xae, 0x03, 0xdf, 0xcf, 0xb2, 0x50, 0x38, 0x08, - 0x59, 0x7b, 0xd5, 0x2b, 0xb4, 0x93, 0x70, 0xaa, 0xd7, 0x43, 0xed, 0x84, 0x9c, 0xc1, 0x34, 0xa2, - 0x43, 0xf1, 0x5a, 0x23, 0xd3, 0x90, 0xb1, 0xbf, 0x07, 0x00, 0x00, 0xff, 0xff, 0xb3, 0xa9, 0x09, - 0x0c, 0xe4, 0x00, 0x00, 0x00, + // 194 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xe2, 0x92, 0x4a, 0x2d, 0x4b, 0xcd, + 0x2b, 0x29, 0xd6, 0x2f, 0x49, 0x2c, 0xce, 0x2e, 0xd6, 0xaf, 0xca, 0x2c, 0x48, 0xcb, 0xcc, 0x49, + 0xd5, 0x2b, 0x28, 0xca, 0x2f, 0xc9, 0x17, 0x62, 0x05, 0x0b, 0x2a, 0xb5, 0x30, 0x72, 0xb1, 0x47, + 0x41, 0x24, 0x84, 0x94, 0xb9, 0x78, 0x93, 0xf3, 0x73, 0x72, 0x52, 0x93, 0x4b, 0x32, 0xf3, 0xf3, + 0xe2, 0x33, 0x53, 0x24, 0x18, 0x15, 0x18, 0x35, 0x38, 0x83, 0x78, 0x10, 0x82, 0x9e, 0x29, 0x42, + 0x22, 0x5c, 0xac, 0x85, 0xa5, 0xa9, 0x45, 0x95, 0x12, 0x4c, 0x60, 0x49, 0x08, 0x47, 0x48, 0x87, + 0x4b, 0x08, 0xcc, 0x88, 0x4f, 0xad, 0x48, 0x4d, 0x2e, 0x85, 0xe9, 0x67, 0x06, 0x2b, 0x11, 0x00, + 0xcb, 0xb8, 0xc2, 0x24, 0x3c, 0x53, 0x84, 0x04, 0xb8, 0x98, 0x4b, 0x8b, 0x72, 0x24, 0x58, 0xc0, + 0xd2, 0x20, 0xa6, 0x93, 0x49, 0x94, 0x51, 0x7a, 0x66, 0x49, 0x46, 0x69, 0x92, 0x5e, 0x72, 0x7e, + 0xae, 0x7e, 0x52, 0x62, 0x49, 0x72, 0x46, 0x72, 0x7e, 0x51, 0x81, 0x7e, 0x71, 0x72, 0x46, 0x6a, + 0x6e, 0x62, 0xb1, 0x7e, 0x52, 0x69, 0x66, 0x4e, 0x8a, 0x7e, 0x7a, 0xbe, 0x3e, 0xb2, 0x8f, 0x92, + 0xd8, 0xc0, 0x5e, 0x31, 0x06, 0x04, 0x00, 0x00, 0xff, 0xff, 0x62, 0xf4, 0xdf, 0xda, 0xe8, 0x00, + 0x00, 0x00, } diff --git a/vendor/github.com/batchcorp/schemas/build/go/services/dproxy.pb.go b/vendor/github.com/batchcorp/schemas/build/go/services/dproxy.pb.go new file mode 100644 index 00000000..9ba1413d --- /dev/null +++ b/vendor/github.com/batchcorp/schemas/build/go/services/dproxy.pb.go @@ -0,0 +1,530 @@ +// Code generated by protoc-gen-go. DO NOT EDIT. +// source: dproxy.proto + +package services + +import ( + context "context" + fmt "fmt" + events "github.com/batchcorp/schemas/build/go/events" + proto "github.com/golang/protobuf/proto" + grpc "google.golang.org/grpc" + codes "google.golang.org/grpc/codes" + status "google.golang.org/grpc/status" + math "math" +) + +// Reference imports to suppress errors if they are not otherwise used. +var _ = proto.Marshal +var _ = fmt.Errorf +var _ = math.Inf + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the proto package it is being compiled against. +// A compilation error at this line likely means your copy of the +// proto package needs to be updated. +const _ = proto.ProtoPackageIsVersion3 // please upgrade the proto package + +type ReplayEvent_Type int32 + +const ( + ReplayEvent_UNSET ReplayEvent_Type = 0 + ReplayEvent_CREATE_REPLAY ReplayEvent_Type = 1 + ReplayEvent_PAUSE_REPLAY ReplayEvent_Type = 2 + ReplayEvent_RESUME_REPLAY ReplayEvent_Type = 3 + ReplayEvent_ABORT_REPLAY ReplayEvent_Type = 4 + ReplayEvent_FINISH_REPLAY ReplayEvent_Type = 5 +) + +var ReplayEvent_Type_name = map[int32]string{ + 0: "UNSET", + 1: "CREATE_REPLAY", + 2: "PAUSE_REPLAY", + 3: "RESUME_REPLAY", + 4: "ABORT_REPLAY", + 5: "FINISH_REPLAY", +} + +var ReplayEvent_Type_value = map[string]int32{ + "UNSET": 0, + "CREATE_REPLAY": 1, + "PAUSE_REPLAY": 2, + "RESUME_REPLAY": 3, + "ABORT_REPLAY": 4, + "FINISH_REPLAY": 5, +} + +func (x ReplayEvent_Type) String() string { + return proto.EnumName(ReplayEvent_Type_name, int32(x)) +} + +func (ReplayEvent_Type) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{2, 0} +} + +type DynamicReplay_Type int32 + +const ( + DynamicReplay_UNSET DynamicReplay_Type = 0 + // Sent by plumber to dProxy + DynamicReplay_AUTH_REQUEST DynamicReplay_Type = 1 + // Sent by dProxy to plumber + DynamicReplay_AUTH_RESPONSE DynamicReplay_Type = 2 + // Sent by dProxy to plumber + // Contains an events.Outbound message with a replay payload + DynamicReplay_OUTBOUND_MESSAGE DynamicReplay_Type = 3 + // Sent by dProxy to plumber + // Replicates an ISB replay event message for display in plumber logs + DynamicReplay_REPLAY_EVENT DynamicReplay_Type = 4 +) + +var DynamicReplay_Type_name = map[int32]string{ + 0: "UNSET", + 1: "AUTH_REQUEST", + 2: "AUTH_RESPONSE", + 3: "OUTBOUND_MESSAGE", + 4: "REPLAY_EVENT", +} + +var DynamicReplay_Type_value = map[string]int32{ + "UNSET": 0, + "AUTH_REQUEST": 1, + "AUTH_RESPONSE": 2, + "OUTBOUND_MESSAGE": 3, + "REPLAY_EVENT": 4, +} + +func (x DynamicReplay_Type) String() string { + return proto.EnumName(DynamicReplay_Type_name, int32(x)) +} + +func (DynamicReplay_Type) EnumDescriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{3, 0} +} + +type AuthRequest struct { + Token string `protobuf:"bytes,1,opt,name=token,proto3" json:"token,omitempty"` + MessageBus string `protobuf:"bytes,2,opt,name=message_bus,json=messageBus,proto3" json:"message_bus,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *AuthRequest) Reset() { *m = AuthRequest{} } +func (m *AuthRequest) String() string { return proto.CompactTextString(m) } +func (*AuthRequest) ProtoMessage() {} +func (*AuthRequest) Descriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{0} +} + +func (m *AuthRequest) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_AuthRequest.Unmarshal(m, b) +} +func (m *AuthRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_AuthRequest.Marshal(b, m, deterministic) +} +func (m *AuthRequest) XXX_Merge(src proto.Message) { + xxx_messageInfo_AuthRequest.Merge(m, src) +} +func (m *AuthRequest) XXX_Size() int { + return xxx_messageInfo_AuthRequest.Size(m) +} +func (m *AuthRequest) XXX_DiscardUnknown() { + xxx_messageInfo_AuthRequest.DiscardUnknown(m) +} + +var xxx_messageInfo_AuthRequest proto.InternalMessageInfo + +func (m *AuthRequest) GetToken() string { + if m != nil { + return m.Token + } + return "" +} + +func (m *AuthRequest) GetMessageBus() string { + if m != nil { + return m.MessageBus + } + return "" +} + +type AuthResponse struct { + // Whether or not the connection is authorized + Authorized bool `protobuf:"varint,1,opt,name=authorized,proto3" json:"authorized,omitempty"` + // Error message if any + Message string `protobuf:"bytes,2,opt,name=message,proto3" json:"message,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *AuthResponse) Reset() { *m = AuthResponse{} } +func (m *AuthResponse) String() string { return proto.CompactTextString(m) } +func (*AuthResponse) ProtoMessage() {} +func (*AuthResponse) Descriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{1} +} + +func (m *AuthResponse) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_AuthResponse.Unmarshal(m, b) +} +func (m *AuthResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_AuthResponse.Marshal(b, m, deterministic) +} +func (m *AuthResponse) XXX_Merge(src proto.Message) { + xxx_messageInfo_AuthResponse.Merge(m, src) +} +func (m *AuthResponse) XXX_Size() int { + return xxx_messageInfo_AuthResponse.Size(m) +} +func (m *AuthResponse) XXX_DiscardUnknown() { + xxx_messageInfo_AuthResponse.DiscardUnknown(m) +} + +var xxx_messageInfo_AuthResponse proto.InternalMessageInfo + +func (m *AuthResponse) GetAuthorized() bool { + if m != nil { + return m.Authorized + } + return false +} + +func (m *AuthResponse) GetMessage() string { + if m != nil { + return m.Message + } + return "" +} + +type ReplayEvent struct { + Type ReplayEvent_Type `protobuf:"varint,1,opt,name=type,proto3,enum=services.ReplayEvent_Type" json:"type,omitempty"` + ReplayId string `protobuf:"bytes,2,opt,name=replay_id,json=replayId,proto3" json:"replay_id,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *ReplayEvent) Reset() { *m = ReplayEvent{} } +func (m *ReplayEvent) String() string { return proto.CompactTextString(m) } +func (*ReplayEvent) ProtoMessage() {} +func (*ReplayEvent) Descriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{2} +} + +func (m *ReplayEvent) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_ReplayEvent.Unmarshal(m, b) +} +func (m *ReplayEvent) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_ReplayEvent.Marshal(b, m, deterministic) +} +func (m *ReplayEvent) XXX_Merge(src proto.Message) { + xxx_messageInfo_ReplayEvent.Merge(m, src) +} +func (m *ReplayEvent) XXX_Size() int { + return xxx_messageInfo_ReplayEvent.Size(m) +} +func (m *ReplayEvent) XXX_DiscardUnknown() { + xxx_messageInfo_ReplayEvent.DiscardUnknown(m) +} + +var xxx_messageInfo_ReplayEvent proto.InternalMessageInfo + +func (m *ReplayEvent) GetType() ReplayEvent_Type { + if m != nil { + return m.Type + } + return ReplayEvent_UNSET +} + +func (m *ReplayEvent) GetReplayId() string { + if m != nil { + return m.ReplayId + } + return "" +} + +// DynamicReplay is an envelope message for dynamic replay communication from dproxy to plumber +type DynamicReplay struct { + Type DynamicReplay_Type `protobuf:"varint,1,opt,name=type,proto3,enum=services.DynamicReplay_Type" json:"type,omitempty"` + ReplayId string `protobuf:"bytes,2,opt,name=replay_id,json=replayId,proto3" json:"replay_id,omitempty"` + // Types that are valid to be assigned to Payload: + // *DynamicReplay_AuthRequest + // *DynamicReplay_AuthResponse + // *DynamicReplay_OutboundMessage + // *DynamicReplay_ReplayMessage + Payload isDynamicReplay_Payload `protobuf_oneof:"payload"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *DynamicReplay) Reset() { *m = DynamicReplay{} } +func (m *DynamicReplay) String() string { return proto.CompactTextString(m) } +func (*DynamicReplay) ProtoMessage() {} +func (*DynamicReplay) Descriptor() ([]byte, []int) { + return fileDescriptor_f7679bc9a582d949, []int{3} +} + +func (m *DynamicReplay) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_DynamicReplay.Unmarshal(m, b) +} +func (m *DynamicReplay) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_DynamicReplay.Marshal(b, m, deterministic) +} +func (m *DynamicReplay) XXX_Merge(src proto.Message) { + xxx_messageInfo_DynamicReplay.Merge(m, src) +} +func (m *DynamicReplay) XXX_Size() int { + return xxx_messageInfo_DynamicReplay.Size(m) +} +func (m *DynamicReplay) XXX_DiscardUnknown() { + xxx_messageInfo_DynamicReplay.DiscardUnknown(m) +} + +var xxx_messageInfo_DynamicReplay proto.InternalMessageInfo + +func (m *DynamicReplay) GetType() DynamicReplay_Type { + if m != nil { + return m.Type + } + return DynamicReplay_UNSET +} + +func (m *DynamicReplay) GetReplayId() string { + if m != nil { + return m.ReplayId + } + return "" +} + +type isDynamicReplay_Payload interface { + isDynamicReplay_Payload() +} + +type DynamicReplay_AuthRequest struct { + AuthRequest *AuthRequest `protobuf:"bytes,100,opt,name=auth_request,json=authRequest,proto3,oneof"` +} + +type DynamicReplay_AuthResponse struct { + AuthResponse *AuthResponse `protobuf:"bytes,101,opt,name=auth_response,json=authResponse,proto3,oneof"` +} + +type DynamicReplay_OutboundMessage struct { + OutboundMessage *events.Outbound `protobuf:"bytes,102,opt,name=outbound_message,json=outboundMessage,proto3,oneof"` +} + +type DynamicReplay_ReplayMessage struct { + ReplayMessage *ReplayEvent `protobuf:"bytes,103,opt,name=replay_message,json=replayMessage,proto3,oneof"` +} + +func (*DynamicReplay_AuthRequest) isDynamicReplay_Payload() {} + +func (*DynamicReplay_AuthResponse) isDynamicReplay_Payload() {} + +func (*DynamicReplay_OutboundMessage) isDynamicReplay_Payload() {} + +func (*DynamicReplay_ReplayMessage) isDynamicReplay_Payload() {} + +func (m *DynamicReplay) GetPayload() isDynamicReplay_Payload { + if m != nil { + return m.Payload + } + return nil +} + +func (m *DynamicReplay) GetAuthRequest() *AuthRequest { + if x, ok := m.GetPayload().(*DynamicReplay_AuthRequest); ok { + return x.AuthRequest + } + return nil +} + +func (m *DynamicReplay) GetAuthResponse() *AuthResponse { + if x, ok := m.GetPayload().(*DynamicReplay_AuthResponse); ok { + return x.AuthResponse + } + return nil +} + +func (m *DynamicReplay) GetOutboundMessage() *events.Outbound { + if x, ok := m.GetPayload().(*DynamicReplay_OutboundMessage); ok { + return x.OutboundMessage + } + return nil +} + +func (m *DynamicReplay) GetReplayMessage() *ReplayEvent { + if x, ok := m.GetPayload().(*DynamicReplay_ReplayMessage); ok { + return x.ReplayMessage + } + return nil +} + +// XXX_OneofWrappers is for the internal use of the proto package. +func (*DynamicReplay) XXX_OneofWrappers() []interface{} { + return []interface{}{ + (*DynamicReplay_AuthRequest)(nil), + (*DynamicReplay_AuthResponse)(nil), + (*DynamicReplay_OutboundMessage)(nil), + (*DynamicReplay_ReplayMessage)(nil), + } +} + +func init() { + proto.RegisterEnum("services.ReplayEvent_Type", ReplayEvent_Type_name, ReplayEvent_Type_value) + proto.RegisterEnum("services.DynamicReplay_Type", DynamicReplay_Type_name, DynamicReplay_Type_value) + proto.RegisterType((*AuthRequest)(nil), "services.AuthRequest") + proto.RegisterType((*AuthResponse)(nil), "services.AuthResponse") + proto.RegisterType((*ReplayEvent)(nil), "services.ReplayEvent") + proto.RegisterType((*DynamicReplay)(nil), "services.DynamicReplay") +} + +func init() { proto.RegisterFile("dproxy.proto", fileDescriptor_f7679bc9a582d949) } + +var fileDescriptor_f7679bc9a582d949 = []byte{ + // 552 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x8c, 0x93, 0x4b, 0x6f, 0x9b, 0x4e, + 0x14, 0xc5, 0x4d, 0xe2, 0x3c, 0x7c, 0x6d, 0xe7, 0x4f, 0x46, 0xc9, 0xbf, 0x56, 0x5a, 0xb5, 0x11, + 0xab, 0xac, 0x20, 0x4a, 0x77, 0x95, 0x52, 0x09, 0xc7, 0xd3, 0x60, 0xa9, 0x7e, 0x74, 0x80, 0x4a, + 0xed, 0xa2, 0x88, 0xc7, 0xd4, 0xa0, 0xda, 0x0c, 0x65, 0x20, 0x2a, 0xfd, 0x7a, 0xdd, 0xf5, 0x53, + 0x55, 0x30, 0xe0, 0x90, 0x54, 0x91, 0xba, 0xe4, 0xdc, 0x73, 0x8e, 0xe6, 0xf2, 0x9b, 0x81, 0x41, + 0x90, 0xa4, 0xec, 0x47, 0xa1, 0x26, 0x29, 0xcb, 0x18, 0x3a, 0xe4, 0x34, 0xbd, 0x8b, 0x7c, 0xca, + 0xcf, 0x4e, 0xe9, 0x1d, 0x8d, 0x33, 0xae, 0xb1, 0x3c, 0xf3, 0x58, 0x1e, 0x07, 0xc2, 0xa0, 0x4c, + 0xa0, 0xaf, 0xe7, 0x59, 0x48, 0xe8, 0xf7, 0x9c, 0xf2, 0x0c, 0x9d, 0xc0, 0x5e, 0xc6, 0xbe, 0xd1, + 0x78, 0x24, 0x9d, 0x4b, 0x17, 0x3d, 0x22, 0x3e, 0xd0, 0x2b, 0xe8, 0x6f, 0x28, 0xe7, 0xee, 0x8a, + 0x3a, 0x5e, 0xce, 0x47, 0x3b, 0xd5, 0x0c, 0x6a, 0x69, 0x9c, 0x73, 0xc5, 0x80, 0x81, 0x68, 0xe1, + 0x09, 0x8b, 0x39, 0x45, 0x2f, 0x01, 0xdc, 0x3c, 0x0b, 0x59, 0x1a, 0xfd, 0xa4, 0x41, 0xd5, 0x75, + 0x48, 0x5a, 0x0a, 0x1a, 0xc1, 0x41, 0x9d, 0xae, 0xcb, 0x9a, 0x4f, 0xe5, 0xb7, 0x04, 0x7d, 0x42, + 0x93, 0xb5, 0x5b, 0xe0, 0xf2, 0xbc, 0x48, 0x85, 0x6e, 0x56, 0x24, 0xb4, 0xea, 0x38, 0xba, 0x3a, + 0x53, 0x9b, 0x7d, 0xd4, 0x96, 0x49, 0xb5, 0x8a, 0x84, 0x92, 0xca, 0x87, 0x9e, 0x43, 0x2f, 0xad, + 0x26, 0x4e, 0x14, 0xd4, 0xdd, 0x87, 0x42, 0x98, 0x06, 0x4a, 0x0c, 0xdd, 0xd2, 0x8a, 0x7a, 0xb0, + 0x67, 0xcf, 0x4d, 0x6c, 0xc9, 0x1d, 0x74, 0x0c, 0xc3, 0x1b, 0x82, 0x75, 0x0b, 0x3b, 0x04, 0x2f, + 0xdf, 0xeb, 0x9f, 0x64, 0x09, 0xc9, 0x30, 0x58, 0xea, 0xb6, 0xb9, 0x55, 0x76, 0x4a, 0x13, 0xc1, + 0xa6, 0x3d, 0xdb, 0x4a, 0xbb, 0xa5, 0x49, 0x1f, 0x2f, 0x88, 0xd5, 0x28, 0xdd, 0xd2, 0xf4, 0x6e, + 0x3a, 0x9f, 0x9a, 0x46, 0x23, 0xed, 0x29, 0xbf, 0x76, 0x61, 0x38, 0x29, 0x62, 0x77, 0x13, 0xf9, + 0xe2, 0xb8, 0xe8, 0xf2, 0xc1, 0x3a, 0x2f, 0xee, 0xd7, 0x79, 0x60, 0xfb, 0xd7, 0x85, 0xd0, 0x1b, + 0x18, 0x94, 0x7f, 0xd5, 0x49, 0x05, 0xbe, 0x51, 0x70, 0x2e, 0x5d, 0xf4, 0xaf, 0x4e, 0xef, 0x6b, + 0x5b, 0x6c, 0x8d, 0x0e, 0xe9, 0xbb, 0x2d, 0xd4, 0xd7, 0x30, 0xac, 0xb3, 0x02, 0xda, 0x88, 0x56, + 0xe1, 0xff, 0x1f, 0x87, 0xc5, 0xd4, 0xe8, 0x90, 0x81, 0xdb, 0x46, 0x7c, 0x0d, 0x72, 0x73, 0x95, + 0x9c, 0x86, 0xe5, 0xd7, 0xaa, 0x41, 0x56, 0xc5, 0x55, 0x53, 0x17, 0xf5, 0xdc, 0xe8, 0x90, 0xff, + 0x1a, 0xef, 0x4c, 0x58, 0xd1, 0x5b, 0x38, 0xaa, 0xd7, 0x6a, 0xc2, 0xab, 0xc7, 0x67, 0x6f, 0x11, + 0x36, 0x3a, 0x64, 0x28, 0xec, 0x75, 0x5e, 0xf9, 0xf2, 0x37, 0xca, 0x12, 0x89, 0x6d, 0x95, 0xbf, + 0xff, 0x83, 0x8d, 0x4d, 0x4b, 0x96, 0x4a, 0x24, 0xb5, 0x62, 0x2e, 0x17, 0x73, 0x13, 0xcb, 0x3b, + 0xe8, 0x04, 0xe4, 0x85, 0x6d, 0x8d, 0x17, 0xf6, 0x7c, 0xe2, 0xcc, 0xb0, 0x69, 0xea, 0xb7, 0x58, + 0xd0, 0x14, 0xd0, 0x1c, 0xfc, 0x11, 0xcf, 0x2d, 0xb9, 0x3b, 0xee, 0xc1, 0x41, 0xe2, 0x16, 0x6b, + 0xe6, 0x06, 0x57, 0xb7, 0xb0, 0x3f, 0x59, 0x96, 0x6f, 0x0a, 0x5d, 0xc3, 0xc1, 0x0d, 0x8b, 0x63, + 0xea, 0x67, 0xe8, 0xd9, 0x13, 0xe8, 0xce, 0x9e, 0x1a, 0x5c, 0x4a, 0x63, 0x0c, 0xc7, 0x3c, 0x54, + 0x3d, 0x37, 0xf3, 0xc3, 0xad, 0x69, 0x29, 0x7d, 0x56, 0x57, 0x51, 0x16, 0xe6, 0x9e, 0xea, 0xb3, + 0x8d, 0x56, 0x0d, 0x7d, 0x96, 0x26, 0x1a, 0xf7, 0x43, 0xba, 0x71, 0xb9, 0xe6, 0xe5, 0xd1, 0x3a, + 0xd0, 0x56, 0x4c, 0x6b, 0x12, 0xde, 0x7e, 0xf5, 0x72, 0x5f, 0xff, 0x09, 0x00, 0x00, 0xff, 0xff, + 0xab, 0x9c, 0x6b, 0xa3, 0xea, 0x03, 0x00, 0x00, +} + +// Reference imports to suppress errors if they are not otherwise used. +var _ context.Context +var _ grpc.ClientConn + +// This is a compile-time assertion to ensure that this generated file +// is compatible with the grpc package it is being compiled against. +const _ = grpc.SupportPackageIsVersion4 + +// DProxyClient is the client API for DProxy service. +// +// For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream. +type DProxyClient interface { + Connect(ctx context.Context, in *DynamicReplay, opts ...grpc.CallOption) (DProxy_ConnectClient, error) +} + +type dProxyClient struct { + cc *grpc.ClientConn +} + +func NewDProxyClient(cc *grpc.ClientConn) DProxyClient { + return &dProxyClient{cc} +} + +func (c *dProxyClient) Connect(ctx context.Context, in *DynamicReplay, opts ...grpc.CallOption) (DProxy_ConnectClient, error) { + stream, err := c.cc.NewStream(ctx, &_DProxy_serviceDesc.Streams[0], "/services.DProxy/Connect", opts...) + if err != nil { + return nil, err + } + x := &dProxyConnectClient{stream} + if err := x.ClientStream.SendMsg(in); err != nil { + return nil, err + } + if err := x.ClientStream.CloseSend(); err != nil { + return nil, err + } + return x, nil +} + +type DProxy_ConnectClient interface { + Recv() (*DynamicReplay, error) + grpc.ClientStream +} + +type dProxyConnectClient struct { + grpc.ClientStream +} + +func (x *dProxyConnectClient) Recv() (*DynamicReplay, error) { + m := new(DynamicReplay) + if err := x.ClientStream.RecvMsg(m); err != nil { + return nil, err + } + return m, nil +} + +// DProxyServer is the server API for DProxy service. +type DProxyServer interface { + Connect(*DynamicReplay, DProxy_ConnectServer) error +} + +// UnimplementedDProxyServer can be embedded to have forward compatible implementations. +type UnimplementedDProxyServer struct { +} + +func (*UnimplementedDProxyServer) Connect(req *DynamicReplay, srv DProxy_ConnectServer) error { + return status.Errorf(codes.Unimplemented, "method Connect not implemented") +} + +func RegisterDProxyServer(s *grpc.Server, srv DProxyServer) { + s.RegisterService(&_DProxy_serviceDesc, srv) +} + +func _DProxy_Connect_Handler(srv interface{}, stream grpc.ServerStream) error { + m := new(DynamicReplay) + if err := stream.RecvMsg(m); err != nil { + return err + } + return srv.(DProxyServer).Connect(m, &dProxyConnectServer{stream}) +} + +type DProxy_ConnectServer interface { + Send(*DynamicReplay) error + grpc.ServerStream +} + +type dProxyConnectServer struct { + grpc.ServerStream +} + +func (x *dProxyConnectServer) Send(m *DynamicReplay) error { + return x.ServerStream.SendMsg(m) +} + +var _DProxy_serviceDesc = grpc.ServiceDesc{ + ServiceName: "services.DProxy", + HandlerType: (*DProxyServer)(nil), + Methods: []grpc.MethodDesc{}, + Streams: []grpc.StreamDesc{ + { + StreamName: "Connect", + Handler: _DProxy_Connect_Handler, + ServerStreams: true, + }, + }, + Metadata: "dproxy.proto", +} diff --git a/vendor/github.com/batchcorp/schemas/build/go/services/grpc-collector.pb.go b/vendor/github.com/batchcorp/schemas/build/go/services/grpc-collector.pb.go index e9e293a4..b6dc0a53 100644 --- a/vendor/github.com/batchcorp/schemas/build/go/services/grpc-collector.pb.go +++ b/vendor/github.com/batchcorp/schemas/build/go/services/grpc-collector.pb.go @@ -714,6 +714,92 @@ func (m *RedisStreamsRecordResponse) GetStatus() *events.Status { return nil } +type MQTTRecordRequest struct { + Records []*records.MQTTRecord `protobuf:"bytes,1,rep,name=records,proto3" json:"records,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *MQTTRecordRequest) Reset() { *m = MQTTRecordRequest{} } +func (m *MQTTRecordRequest) String() string { return proto.CompactTextString(m) } +func (*MQTTRecordRequest) ProtoMessage() {} +func (*MQTTRecordRequest) Descriptor() ([]byte, []int) { + return fileDescriptor_b14fa3ba2d2da9b2, []int{16} +} + +func (m *MQTTRecordRequest) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_MQTTRecordRequest.Unmarshal(m, b) +} +func (m *MQTTRecordRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_MQTTRecordRequest.Marshal(b, m, deterministic) +} +func (m *MQTTRecordRequest) XXX_Merge(src proto.Message) { + xxx_messageInfo_MQTTRecordRequest.Merge(m, src) +} +func (m *MQTTRecordRequest) XXX_Size() int { + return xxx_messageInfo_MQTTRecordRequest.Size(m) +} +func (m *MQTTRecordRequest) XXX_DiscardUnknown() { + xxx_messageInfo_MQTTRecordRequest.DiscardUnknown(m) +} + +var xxx_messageInfo_MQTTRecordRequest proto.InternalMessageInfo + +func (m *MQTTRecordRequest) GetRecords() []*records.MQTTRecord { + if m != nil { + return m.Records + } + return nil +} + +type MQTTRecordResponse struct { + NumRecordsProcessed int64 `protobuf:"varint,1,opt,name=num_records_processed,json=numRecordsProcessed,proto3" json:"num_records_processed,omitempty"` + Status *events.Status `protobuf:"bytes,2,opt,name=status,proto3" json:"status,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` +} + +func (m *MQTTRecordResponse) Reset() { *m = MQTTRecordResponse{} } +func (m *MQTTRecordResponse) String() string { return proto.CompactTextString(m) } +func (*MQTTRecordResponse) ProtoMessage() {} +func (*MQTTRecordResponse) Descriptor() ([]byte, []int) { + return fileDescriptor_b14fa3ba2d2da9b2, []int{17} +} + +func (m *MQTTRecordResponse) XXX_Unmarshal(b []byte) error { + return xxx_messageInfo_MQTTRecordResponse.Unmarshal(m, b) +} +func (m *MQTTRecordResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + return xxx_messageInfo_MQTTRecordResponse.Marshal(b, m, deterministic) +} +func (m *MQTTRecordResponse) XXX_Merge(src proto.Message) { + xxx_messageInfo_MQTTRecordResponse.Merge(m, src) +} +func (m *MQTTRecordResponse) XXX_Size() int { + return xxx_messageInfo_MQTTRecordResponse.Size(m) +} +func (m *MQTTRecordResponse) XXX_DiscardUnknown() { + xxx_messageInfo_MQTTRecordResponse.DiscardUnknown(m) +} + +var xxx_messageInfo_MQTTRecordResponse proto.InternalMessageInfo + +func (m *MQTTRecordResponse) GetNumRecordsProcessed() int64 { + if m != nil { + return m.NumRecordsProcessed + } + return 0 +} + +func (m *MQTTRecordResponse) GetStatus() *events.Status { + if m != nil { + return m.Status + } + return nil +} + type TestRequest struct { XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -724,7 +810,7 @@ func (m *TestRequest) Reset() { *m = TestRequest{} } func (m *TestRequest) String() string { return proto.CompactTextString(m) } func (*TestRequest) ProtoMessage() {} func (*TestRequest) Descriptor() ([]byte, []int) { - return fileDescriptor_b14fa3ba2d2da9b2, []int{16} + return fileDescriptor_b14fa3ba2d2da9b2, []int{18} } func (m *TestRequest) XXX_Unmarshal(b []byte) error { @@ -756,7 +842,7 @@ func (m *TestResponse) Reset() { *m = TestResponse{} } func (m *TestResponse) String() string { return proto.CompactTextString(m) } func (*TestResponse) ProtoMessage() {} func (*TestResponse) Descriptor() ([]byte, []int) { - return fileDescriptor_b14fa3ba2d2da9b2, []int{17} + return fileDescriptor_b14fa3ba2d2da9b2, []int{19} } func (m *TestResponse) XXX_Unmarshal(b []byte) error { @@ -801,6 +887,8 @@ func init() { proto.RegisterType((*RedisRecordResponse)(nil), "services.RedisRecordResponse") proto.RegisterType((*RedisStreamsRecordRequest)(nil), "services.RedisStreamsRecordRequest") proto.RegisterType((*RedisStreamsRecordResponse)(nil), "services.RedisStreamsRecordResponse") + proto.RegisterType((*MQTTRecordRequest)(nil), "services.MQTTRecordRequest") + proto.RegisterType((*MQTTRecordResponse)(nil), "services.MQTTRecordResponse") proto.RegisterType((*TestRequest)(nil), "services.TestRequest") proto.RegisterType((*TestResponse)(nil), "services.TestResponse") } @@ -808,49 +896,52 @@ func init() { func init() { proto.RegisterFile("grpc-collector.proto", fileDescriptor_b14fa3ba2d2da9b2) } var fileDescriptor_b14fa3ba2d2da9b2 = []byte{ - // 662 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xbc, 0x96, 0x5f, 0x6f, 0xd3, 0x30, - 0x14, 0xc5, 0x15, 0x06, 0x03, 0xee, 0xfe, 0x88, 0x79, 0xeb, 0xd6, 0x79, 0x03, 0x4a, 0x41, 0x68, - 0x0f, 0x2c, 0x81, 0xa2, 0xf1, 0x4c, 0x18, 0xd0, 0x09, 0x36, 0xa9, 0x4b, 0xe1, 0x85, 0x97, 0x29, - 0xb5, 0x4d, 0x1b, 0x6d, 0xf9, 0x53, 0x3b, 0x99, 0x10, 0x5f, 0x91, 0x2f, 0x85, 0x9a, 0x38, 0x89, - 0xe3, 0xa6, 0xd5, 0x9e, 0xf2, 0x98, 0x9c, 0x73, 0x8f, 0x7f, 0x76, 0x7d, 0x6f, 0x0a, 0x3b, 0x63, - 0x1e, 0x91, 0x63, 0x12, 0xde, 0xdc, 0x30, 0x12, 0x87, 0xdc, 0x8c, 0x78, 0x18, 0x87, 0xe8, 0x91, - 0x60, 0xfc, 0xd6, 0x23, 0x4c, 0xe0, 0x6d, 0x76, 0xcb, 0x82, 0x58, 0x58, 0x22, 0x76, 0xe3, 0x44, - 0x64, 0x32, 0x3e, 0x94, 0x2f, 0x39, 0x23, 0x21, 0xa7, 0xc2, 0x1a, 0xb3, 0x80, 0x71, 0x8f, 0x48, - 0x75, 0x5f, 0x53, 0x5d, 0x7f, 0x1a, 0x49, 0x09, 0x6b, 0xd2, 0xb5, 0xfb, 0xfb, 0xda, 0x95, 0x5a, - 0x5b, 0xd3, 0xc4, 0x54, 0x2c, 0xa8, 0x72, 0xff, 0x26, 0x9c, 0x2d, 0xa8, 0x1a, 0x93, 0x45, 0x6b, - 0x71, 0x46, 0xbd, 0x3c, 0xb1, 0x5b, 0xa7, 0x1d, 0x8b, 0x98, 0x33, 0xd7, 0x97, 0x9e, 0xee, 0x19, - 0xec, 0xf4, 0xb3, 0x7d, 0x39, 0xa9, 0xcb, 0x61, 0xd3, 0x84, 0x89, 0x18, 0xbd, 0x85, 0x87, 0xb2, - 0xac, 0x6d, 0x74, 0x56, 0x8e, 0xd6, 0x7a, 0xbb, 0xa6, 0x7c, 0x36, 0xab, 0xfe, 0xdc, 0xd6, 0x15, - 0xd0, 0xd2, 0x92, 0x44, 0x14, 0x06, 0x82, 0xa1, 0x1e, 0xb4, 0x82, 0xc4, 0xbf, 0x92, 0xbe, 0xab, - 0x88, 0x87, 0x84, 0x09, 0xc1, 0x68, 0xdb, 0xe8, 0x18, 0x47, 0x2b, 0xce, 0x76, 0x90, 0xf8, 0x59, - 0x85, 0x18, 0xe4, 0x12, 0x7a, 0x0d, 0xab, 0xd9, 0x6f, 0xd1, 0xbe, 0xd7, 0x31, 0x8e, 0xd6, 0x7a, - 0x9b, 0x66, 0xb6, 0x17, 0x73, 0x98, 0xbe, 0x75, 0xa4, 0xda, 0xfd, 0x0a, 0x5b, 0xf6, 0xc5, 0xe5, - 0xa0, 0xca, 0xfe, 0x4e, 0x67, 0xdf, 0x2b, 0xd8, 0x67, 0xe6, 0xa1, 0x17, 0x5c, 0xeb, 0xf0, 0x11, - 0x20, 0x35, 0xa7, 0x01, 0xf2, 0x73, 0xd8, 0xfd, 0x3e, 0xbb, 0x17, 0x0a, 0x8d, 0xc4, 0xef, 0xe9, - 0xf8, 0xed, 0x02, 0x5f, 0xaf, 0x28, 0xf8, 0x13, 0xd8, 0x9b, 0x4b, 0x6b, 0x60, 0x13, 0x1f, 0xe1, - 0xc9, 0xf0, 0x72, 0x58, 0xc5, 0x7f, 0xa3, 0xe3, 0xa3, 0x02, 0xbf, 0xf4, 0x16, 0xe0, 0x21, 0x6c, - 0x29, 0x09, 0x0d, 0x20, 0x9f, 0x01, 0xb2, 0x67, 0x9d, 0x75, 0xe7, 0x33, 0x4f, 0xdd, 0x75, 0x67, - 0x3e, 0x85, 0xed, 0x4a, 0x52, 0x33, 0xe7, 0xdd, 0x3f, 0x1d, 0xdc, 0xf9, 0xbc, 0x4b, 0xaf, 0x7a, - 0xde, 0x4a, 0x42, 0x03, 0xc8, 0x9f, 0x01, 0x39, 0xb3, 0xb9, 0x53, 0x85, 0x36, 0x75, 0xe8, 0x9d, - 0x02, 0x5a, 0x75, 0xab, 0x67, 0x5d, 0x49, 0x69, 0x00, 0xdc, 0x81, 0xfd, 0x74, 0xc9, 0x61, 0x36, - 0x2f, 0xab, 0xfc, 0x27, 0x3a, 0xff, 0x41, 0x95, 0xbf, 0x5a, 0x54, 0x6c, 0xe3, 0x0f, 0xe0, 0xba, - 0xcc, 0x06, 0x76, 0xb3, 0x01, 0x6b, 0x3f, 0x98, 0x88, 0x25, 0x7f, 0xf7, 0x03, 0xac, 0x67, 0x8f, - 0x72, 0xe9, 0x32, 0xc6, 0x58, 0x16, 0xd3, 0xfb, 0xf7, 0x00, 0x36, 0xfa, 0xce, 0xe0, 0xf4, 0x34, - 0xff, 0x94, 0xa2, 0x73, 0x78, 0x6c, 0x53, 0x9a, 0x71, 0xa1, 0x67, 0x66, 0xfe, 0x49, 0x35, 0xeb, - 0xbe, 0x2a, 0xf8, 0xf9, 0x42, 0x5d, 0x72, 0x7c, 0x83, 0x0d, 0x9b, 0xd2, 0x72, 0x14, 0xa3, 0x83, - 0xb2, 0x62, 0x6e, 0xd0, 0xe3, 0xc3, 0x7a, 0x51, 0x66, 0xfd, 0x84, 0x4d, 0x9b, 0xd2, 0x74, 0x2c, - 0xca, 0xb0, 0x4e, 0xe9, 0xaf, 0x9f, 0xbd, 0xf8, 0xc5, 0x12, 0x87, 0x8c, 0xed, 0xc3, 0xba, 0x4d, - 0x69, 0x31, 0xb4, 0x10, 0x2e, 0x4b, 0xf4, 0x59, 0x88, 0x0f, 0x6a, 0x35, 0x19, 0x74, 0x91, 0xf2, - 0x29, 0x23, 0x04, 0xa9, 0xfb, 0x99, 0x9b, 0x51, 0xf8, 0xe9, 0x02, 0xb5, 0xc2, 0x55, 0x34, 0xb7, - 0xca, 0xa5, 0xcf, 0x0c, 0x95, 0x6b, 0x7e, 0x1a, 0x64, 0x5c, 0x4a, 0xbb, 0xa9, 0x5c, 0xf3, 0xbd, - 0xac, 0x72, 0xd5, 0xf5, 0xe8, 0x08, 0x5a, 0x79, 0x5c, 0xe5, 0xda, 0xa3, 0x97, 0x5a, 0x5d, 0x5d, - 0xa3, 0xe1, 0x57, 0xcb, 0x4d, 0x72, 0x8d, 0x13, 0xb8, 0x3f, 0xbb, 0xce, 0xa8, 0x55, 0xba, 0x95, - 0xdb, 0x8e, 0x77, 0xf5, 0xd7, 0x59, 0xd9, 0xa7, 0x2f, 0xb0, 0x25, 0x26, 0xe6, 0xc8, 0x8d, 0xc9, - 0xa4, 0x70, 0x0c, 0x8c, 0x5f, 0xe6, 0xd8, 0x8b, 0x27, 0xc9, 0xc8, 0x24, 0xa1, 0x6f, 0xa5, 0x22, - 0x09, 0x79, 0x64, 0x09, 0x32, 0x61, 0xbe, 0x2b, 0xac, 0x51, 0xe2, 0xdd, 0x50, 0x6b, 0x1c, 0x5a, - 0x79, 0xc5, 0x68, 0x35, 0xfd, 0x2b, 0xf5, 0xfe, 0x7f, 0x00, 0x00, 0x00, 0xff, 0xff, 0xd3, 0x05, - 0xce, 0x84, 0x66, 0x0a, 0x00, 0x00, + // 705 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xbc, 0x96, 0x5f, 0x6f, 0xd3, 0x3c, + 0x14, 0xc6, 0xd5, 0x77, 0xaf, 0x06, 0x9c, 0xfd, 0x11, 0x75, 0xd7, 0xad, 0xcb, 0x06, 0x94, 0x82, + 0xd0, 0x2e, 0x58, 0x02, 0x45, 0xe3, 0x9a, 0x6e, 0x40, 0x27, 0xd8, 0xa4, 0x2e, 0x1d, 0x37, 0xdc, + 0x4c, 0xa9, 0x6d, 0xda, 0x6a, 0x4b, 0x93, 0xda, 0xce, 0x84, 0xf8, 0x22, 0x7c, 0x5d, 0xd4, 0xc4, + 0x49, 0x6c, 0x37, 0xa9, 0x76, 0x95, 0xcb, 0xe6, 0x39, 0xe7, 0xc9, 0xef, 0xb8, 0xf6, 0xe3, 0xc0, + 0xce, 0x98, 0x85, 0xf8, 0x18, 0x07, 0x77, 0x77, 0x14, 0x8b, 0x80, 0xd9, 0x21, 0x0b, 0x44, 0x80, + 0x1e, 0x73, 0xca, 0xee, 0xa7, 0x98, 0x72, 0xab, 0x41, 0xef, 0xe9, 0x4c, 0x70, 0x87, 0x0b, 0x4f, + 0x44, 0x3c, 0x91, 0xad, 0x43, 0xf9, 0x90, 0x51, 0x1c, 0x30, 0xc2, 0x9d, 0x31, 0x9d, 0x51, 0x36, + 0xc5, 0x52, 0xdd, 0x37, 0x54, 0xcf, 0x9f, 0x87, 0x52, 0xb2, 0x0c, 0xe9, 0xd6, 0xfb, 0x75, 0xeb, + 0x49, 0xad, 0x65, 0x68, 0x7c, 0xce, 0x4b, 0xba, 0xbc, 0x3f, 0x11, 0xa3, 0x25, 0x5d, 0x63, 0x5c, + 0xf6, 0x2e, 0x46, 0xc9, 0x34, 0x75, 0xec, 0x14, 0x69, 0xc7, 0x5c, 0x30, 0xea, 0xf9, 0xbc, 0x64, + 0x0c, 0x7f, 0x2e, 0x44, 0x22, 0x75, 0xce, 0x61, 0xa7, 0x9f, 0x8c, 0xec, 0xc6, 0xa2, 0x4b, 0xe7, + 0x11, 0xe5, 0x02, 0xbd, 0x83, 0x47, 0xb2, 0xba, 0x55, 0x6b, 0xaf, 0x1d, 0x6d, 0x74, 0x77, 0x6d, + 0xf9, 0xdb, 0xd6, 0xeb, 0xd3, 0xb2, 0x0e, 0x87, 0xa6, 0xe1, 0xc4, 0xc3, 0x60, 0xc6, 0x29, 0xea, + 0x42, 0x73, 0x16, 0xf9, 0x37, 0xb2, 0xee, 0x26, 0x64, 0x01, 0xa6, 0x9c, 0x53, 0xd2, 0xaa, 0xb5, + 0x6b, 0x47, 0x6b, 0x6e, 0x63, 0x16, 0xf9, 0x49, 0x07, 0x1f, 0xa4, 0x12, 0x7a, 0x03, 0xeb, 0xc9, + 0xdf, 0xd4, 0xfa, 0xaf, 0x5d, 0x3b, 0xda, 0xe8, 0x6e, 0xdb, 0xc9, 0x08, 0xf6, 0x30, 0x7e, 0xea, + 0x4a, 0xb5, 0xf3, 0x15, 0xea, 0xbd, 0xcb, 0xab, 0x81, 0xce, 0xfe, 0xde, 0x64, 0xdf, 0xcb, 0xd8, + 0x17, 0xc5, 0xc3, 0xe9, 0xec, 0xd6, 0x84, 0x0f, 0x01, 0xa9, 0x3e, 0x15, 0x90, 0x5f, 0xc0, 0xee, + 0xf7, 0xc5, 0x96, 0x51, 0x68, 0x24, 0x7e, 0xd7, 0xc4, 0x6f, 0x65, 0xf8, 0x66, 0x47, 0xc6, 0x1f, + 0xc1, 0xde, 0x92, 0x5b, 0x05, 0x43, 0x7c, 0x82, 0xa7, 0xc3, 0xab, 0xa1, 0x8e, 0xff, 0xd6, 0xc4, + 0x47, 0x19, 0x7e, 0x5e, 0x9b, 0x81, 0x07, 0x50, 0x57, 0x1c, 0x2a, 0x40, 0x3e, 0x07, 0xd4, 0x5b, + 0x1c, 0xba, 0x07, 0xaf, 0x79, 0x5c, 0x5d, 0xb4, 0xe6, 0x73, 0x68, 0x68, 0x4e, 0xd5, 0xac, 0x77, + 0xff, 0x6c, 0xf0, 0xe0, 0xf5, 0xce, 0x6b, 0xd5, 0xf5, 0x56, 0x1c, 0x2a, 0x40, 0xfe, 0x0c, 0xc8, + 0x5d, 0x44, 0x92, 0x0e, 0x6d, 0x9b, 0xd0, 0x3b, 0x19, 0xb4, 0x5a, 0xad, 0xae, 0xb5, 0xe6, 0x52, + 0x01, 0xb8, 0x0b, 0xfb, 0xf1, 0x2b, 0x87, 0x49, 0x94, 0xea, 0xfc, 0x27, 0x26, 0xff, 0x81, 0xce, + 0xaf, 0x37, 0x65, 0x63, 0xfc, 0x06, 0xab, 0xc8, 0xb3, 0x82, 0x69, 0x4e, 0xa1, 0x7e, 0x79, 0x75, + 0x7d, 0xad, 0x4f, 0x71, 0x6c, 0x4e, 0xd1, 0xc8, 0xa6, 0x50, 0x8a, 0xd5, 0x90, 0x54, 0x3d, 0x2a, + 0xa0, 0xde, 0x82, 0x8d, 0x6b, 0xca, 0x85, 0xe4, 0xed, 0x7c, 0x84, 0xcd, 0xe4, 0xa7, 0x7c, 0x75, + 0x6e, 0x53, 0x5b, 0x65, 0xd3, 0xfd, 0xbb, 0x0e, 0x5b, 0x7d, 0x77, 0x70, 0x76, 0x96, 0x7e, 0x1b, + 0xa0, 0x0b, 0x78, 0xd2, 0x23, 0x24, 0xe1, 0x42, 0xcf, 0xed, 0xf4, 0x1b, 0xc1, 0x2e, 0xba, 0x0b, + 0xad, 0x17, 0xa5, 0xba, 0xe4, 0xf8, 0x06, 0x5b, 0x3d, 0x42, 0xf2, 0x0b, 0x04, 0x1d, 0xe4, 0x1d, + 0x4b, 0xd7, 0x93, 0x75, 0x58, 0x2c, 0x4a, 0xaf, 0x1f, 0xb0, 0xdd, 0x23, 0x24, 0x0e, 0x73, 0x69, + 0xd6, 0xce, 0xeb, 0x8b, 0x6f, 0x0c, 0xeb, 0xe5, 0x8a, 0x0a, 0x69, 0xdb, 0x87, 0xcd, 0x1e, 0x21, + 0x59, 0xd4, 0x22, 0x2b, 0x6f, 0x31, 0x13, 0xdc, 0x3a, 0x28, 0xd4, 0xa4, 0xd1, 0x65, 0xcc, 0xa7, + 0x04, 0x1f, 0x52, 0xe7, 0x59, 0x4a, 0x56, 0xeb, 0x59, 0x89, 0xaa, 0x71, 0x65, 0x91, 0xa4, 0x72, + 0x99, 0x49, 0xa7, 0x72, 0x2d, 0x67, 0x58, 0xc2, 0xa5, 0x84, 0x84, 0xca, 0xb5, 0x9c, 0x40, 0x2a, + 0x57, 0x51, 0xb2, 0x8c, 0xa0, 0x99, 0xda, 0x69, 0x87, 0x15, 0xbd, 0x32, 0xfa, 0x8a, 0xe2, 0xc1, + 0x7a, 0xbd, 0xba, 0x48, 0xdb, 0x36, 0xf9, 0x91, 0x52, 0xb7, 0xcd, 0xd2, 0x61, 0x55, 0xb7, 0x4d, + 0xc1, 0x29, 0x3c, 0x81, 0xff, 0x17, 0x47, 0x03, 0x35, 0xf3, 0x2a, 0xe5, 0xe4, 0x58, 0xbb, 0xe6, + 0xe3, 0xa4, 0xed, 0xf4, 0x0b, 0xd4, 0xf9, 0xc4, 0x1e, 0x79, 0x02, 0x4f, 0xb2, 0x8a, 0x41, 0xed, + 0xa7, 0x3d, 0x9e, 0x8a, 0x49, 0x34, 0xb2, 0x71, 0xe0, 0x3b, 0xb1, 0x88, 0x03, 0x16, 0x3a, 0x1c, + 0x4f, 0xa8, 0xef, 0x71, 0x67, 0x14, 0x4d, 0xef, 0x88, 0x33, 0x0e, 0x9c, 0xb4, 0x63, 0xb4, 0x1e, + 0x7f, 0x4c, 0x7e, 0xf8, 0x17, 0x00, 0x00, 0xff, 0xff, 0x46, 0x17, 0x83, 0xd5, 0x83, 0x0b, 0x00, + 0x00, } // Reference imports to suppress errors if they are not otherwise used. @@ -873,6 +964,7 @@ type GRPCCollectorClient interface { AddGCPRecord(ctx context.Context, in *GCPRecordRequest, opts ...grpc.CallOption) (*GCPRecordResponse, error) AddRedisRecord(ctx context.Context, in *RedisRecordRequest, opts ...grpc.CallOption) (*RedisRecordResponse, error) AddRedisStreamsRecord(ctx context.Context, in *RedisStreamsRecordRequest, opts ...grpc.CallOption) (*RedisStreamsRecordResponse, error) + AddMQTTRecord(ctx context.Context, in *MQTTRecordRequest, opts ...grpc.CallOption) (*MQTTRecordResponse, error) Test(ctx context.Context, in *TestRequest, opts ...grpc.CallOption) (*TestResponse, error) } @@ -956,6 +1048,15 @@ func (c *gRPCCollectorClient) AddRedisStreamsRecord(ctx context.Context, in *Red return out, nil } +func (c *gRPCCollectorClient) AddMQTTRecord(ctx context.Context, in *MQTTRecordRequest, opts ...grpc.CallOption) (*MQTTRecordResponse, error) { + out := new(MQTTRecordResponse) + err := c.cc.Invoke(ctx, "/services.GRPCCollector/AddMQTTRecord", in, out, opts...) + if err != nil { + return nil, err + } + return out, nil +} + func (c *gRPCCollectorClient) Test(ctx context.Context, in *TestRequest, opts ...grpc.CallOption) (*TestResponse, error) { out := new(TestResponse) err := c.cc.Invoke(ctx, "/services.GRPCCollector/Test", in, out, opts...) @@ -975,6 +1076,7 @@ type GRPCCollectorServer interface { AddGCPRecord(context.Context, *GCPRecordRequest) (*GCPRecordResponse, error) AddRedisRecord(context.Context, *RedisRecordRequest) (*RedisRecordResponse, error) AddRedisStreamsRecord(context.Context, *RedisStreamsRecordRequest) (*RedisStreamsRecordResponse, error) + AddMQTTRecord(context.Context, *MQTTRecordRequest) (*MQTTRecordResponse, error) Test(context.Context, *TestRequest) (*TestResponse, error) } @@ -1006,6 +1108,9 @@ func (*UnimplementedGRPCCollectorServer) AddRedisRecord(ctx context.Context, req func (*UnimplementedGRPCCollectorServer) AddRedisStreamsRecord(ctx context.Context, req *RedisStreamsRecordRequest) (*RedisStreamsRecordResponse, error) { return nil, status.Errorf(codes.Unimplemented, "method AddRedisStreamsRecord not implemented") } +func (*UnimplementedGRPCCollectorServer) AddMQTTRecord(ctx context.Context, req *MQTTRecordRequest) (*MQTTRecordResponse, error) { + return nil, status.Errorf(codes.Unimplemented, "method AddMQTTRecord not implemented") +} func (*UnimplementedGRPCCollectorServer) Test(ctx context.Context, req *TestRequest) (*TestResponse, error) { return nil, status.Errorf(codes.Unimplemented, "method Test not implemented") } @@ -1158,6 +1263,24 @@ func _GRPCCollector_AddRedisStreamsRecord_Handler(srv interface{}, ctx context.C return interceptor(ctx, in, info, handler) } +func _GRPCCollector_AddMQTTRecord_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { + in := new(MQTTRecordRequest) + if err := dec(in); err != nil { + return nil, err + } + if interceptor == nil { + return srv.(GRPCCollectorServer).AddMQTTRecord(ctx, in) + } + info := &grpc.UnaryServerInfo{ + Server: srv, + FullMethod: "/services.GRPCCollector/AddMQTTRecord", + } + handler := func(ctx context.Context, req interface{}) (interface{}, error) { + return srv.(GRPCCollectorServer).AddMQTTRecord(ctx, req.(*MQTTRecordRequest)) + } + return interceptor(ctx, in, info, handler) +} + func _GRPCCollector_Test_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { in := new(TestRequest) if err := dec(in); err != nil { @@ -1212,6 +1335,10 @@ var _GRPCCollector_serviceDesc = grpc.ServiceDesc{ MethodName: "AddRedisStreamsRecord", Handler: _GRPCCollector_AddRedisStreamsRecord_Handler, }, + { + MethodName: "AddMQTTRecord", + Handler: _GRPCCollector_AddMQTTRecord_Handler, + }, { MethodName: "Test", Handler: _GRPCCollector_Test_Handler, diff --git a/vendor/modules.txt b/vendor/modules.txt index f10c83cc..2c135bfb 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -125,7 +125,7 @@ github.com/batchcorp/pgoutput # github.com/batchcorp/rabbit v0.1.9 ## explicit github.com/batchcorp/rabbit -# github.com/batchcorp/schemas v0.2.128 +# github.com/batchcorp/schemas v0.2.154 ## explicit github.com/batchcorp/schemas/build/go/events github.com/batchcorp/schemas/build/go/events/destinations