[VOL-3801] remove consul support

Bump up voltha-lib-go version to remove consul
voltha-protos version is updated automatically by mod-update

Change-Id: Ifad40dc54fb03b1e40ea9f5fe46344dacb2527ee
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/performance_metrics.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/performance_metrics.go
index 6705c72..3b6d4f9 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/performance_metrics.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/performance_metrics.go
@@ -48,6 +48,11 @@
 	}
 }
 
+// UpdateFrequency will update the frequency.
+func (pm *PmMetrics) UpdateFrequency(frequency uint32) {
+	pm.frequency = frequency
+}
+
 func Metrics(pmNames []string) PmMetricsOption {
 	return func(args *PmMetrics) {
 		args.metrics = make(map[string]*voltha.PmConfig)
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/request_handler.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/request_handler.go
index 7d14db7..459cac5 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/request_handler.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/adapters/common/request_handler.go
@@ -559,24 +559,107 @@
 	return new(empty.Empty), nil
 }
 
-func (rhp *RequestHandlerProxy) Download_image(args []*ic.Argument) (*voltha.ImageDownload, error) {
-	return &voltha.ImageDownload{}, nil
+func (rhp *RequestHandlerProxy) Download_image(ctx context.Context, args []*ic.Argument) (*voltha.ImageDownload, error) {
+	device, image, err := unMarshalImageDowload(args, ctx)
+	if err != nil {
+		return nil, err
+	}
+
+	imageDownload, err := rhp.adapter.Download_image(ctx, device, image)
+	if err != nil {
+		return nil, status.Errorf(codes.NotFound, "%s", err.Error())
+	}
+	return imageDownload, nil
 }
 
-func (rhp *RequestHandlerProxy) Get_image_download_status(args []*ic.Argument) (*voltha.ImageDownload, error) {
-	return &voltha.ImageDownload{}, nil
+func (rhp *RequestHandlerProxy) Get_image_download_status(ctx context.Context, args []*ic.Argument) (*voltha.ImageDownload, error) {
+	device, image, err := unMarshalImageDowload(args, ctx)
+	if err != nil {
+		return nil, err
+	}
+
+	imageDownload, err := rhp.adapter.Get_image_download_status(ctx, device, image)
+	if err != nil {
+		return nil, status.Errorf(codes.NotFound, "%s", err.Error())
+	}
+	return imageDownload, nil
 }
 
-func (rhp *RequestHandlerProxy) Cancel_image_download(args []*ic.Argument) (*voltha.ImageDownload, error) {
-	return &voltha.ImageDownload{}, nil
+func (rhp *RequestHandlerProxy) Cancel_image_download(ctx context.Context, args []*ic.Argument) (*voltha.ImageDownload, error) {
+	device, image, err := unMarshalImageDowload(args, ctx)
+	if err != nil {
+		return nil, err
+	}
+
+	imageDownload, err := rhp.adapter.Cancel_image_download(ctx, device, image)
+	if err != nil {
+		return nil, status.Errorf(codes.NotFound, "%s", err.Error())
+	}
+	return imageDownload, nil
 }
 
-func (rhp *RequestHandlerProxy) Activate_image_update(args []*ic.Argument) (*voltha.ImageDownload, error) {
-	return &voltha.ImageDownload{}, nil
+func (rhp *RequestHandlerProxy) Activate_image_update(ctx context.Context, args []*ic.Argument) (*voltha.ImageDownload, error) {
+
+	device, image, err := unMarshalImageDowload(args, ctx)
+	if err != nil {
+		return nil, err
+	}
+
+	imageDownload, err := rhp.adapter.Activate_image_update(ctx, device, image)
+	if err != nil {
+		return nil, status.Errorf(codes.NotFound, "%s", err.Error())
+	}
+	return imageDownload, nil
 }
 
-func (rhp *RequestHandlerProxy) Revert_image_update(args []*ic.Argument) (*voltha.ImageDownload, error) {
-	return &voltha.ImageDownload{}, nil
+func (rhp *RequestHandlerProxy) Revert_image_update(ctx context.Context, args []*ic.Argument) (*voltha.ImageDownload, error) {
+	device, image, err := unMarshalImageDowload(args, ctx)
+	if err != nil {
+		return nil, err
+	}
+
+	imageDownload, err := rhp.adapter.Revert_image_update(ctx, device, image)
+	if err != nil {
+		return nil, status.Errorf(codes.NotFound, "%s", err.Error())
+	}
+	return imageDownload, nil
+}
+
+func unMarshalImageDowload(args []*ic.Argument, ctx context.Context) (*voltha.Device, *voltha.ImageDownload, error) {
+	if len(args) < 4 {
+		logger.Warn(ctx, "invalid-number-of-args", log.Fields{"args": args})
+		err := errors.New("invalid-number-of-args")
+		return nil, nil, err
+	}
+	device := &voltha.Device{}
+	image := &voltha.ImageDownload{}
+	transactionID := &ic.StrType{}
+	fromTopic := &ic.StrType{}
+	for _, arg := range args {
+		switch arg.Key {
+		case "device":
+			if err := ptypes.UnmarshalAny(arg.Value, device); err != nil {
+				logger.Warnw(ctx, "cannot-unmarshal-device", log.Fields{"error": err})
+				return nil, nil, err
+			}
+		case "request":
+			if err := ptypes.UnmarshalAny(arg.Value, image); err != nil {
+				logger.Warnw(ctx, "cannot-unmarshal-image", log.Fields{"error": err})
+				return nil, nil, err
+			}
+		case kafka.TransactionKey:
+			if err := ptypes.UnmarshalAny(arg.Value, transactionID); err != nil {
+				logger.Warnw(ctx, "cannot-unmarshal-transaction-ID", log.Fields{"error": err})
+				return nil, nil, err
+			}
+		case kafka.FromTopic:
+			if err := ptypes.UnmarshalAny(arg.Value, fromTopic); err != nil {
+				logger.Warnw(ctx, "cannot-unmarshal-from-topic", log.Fields{"error": err})
+				return nil, nil, err
+			}
+		}
+	}
+	return device, image, nil
 }
 
 func (rhp *RequestHandlerProxy) Enable_port(ctx context.Context, args []*ic.Argument) error {
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/config/configmanager.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/config/configmanager.go
index 4b1c841..8350225 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/config/configmanager.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/config/configmanager.go
@@ -29,7 +29,7 @@
 
 const (
 	defaultkvStoreConfigPath     = "config"
-	defaultkvStoreDataPathPrefix = "service/voltha"
+	defaultkvStoreDataPathPrefix = "service/voltha_voltha"
 	kvStorePathSeparator         = "/"
 )
 
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/backend.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/backend.go
index d6867a5..bf30a48 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/backend.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/backend.go
@@ -75,8 +75,6 @@
 
 func (b *Backend) newClient(ctx context.Context, address string, timeout time.Duration) (kvstore.Client, error) {
 	switch b.StoreType {
-	case "consul":
-		return kvstore.NewConsulClient(ctx, address, timeout)
 	case "etcd":
 		return kvstore.NewEtcdClient(ctx, address, timeout, log.WarnLevel)
 	}
@@ -170,9 +168,6 @@
 			case codes.DataLoss:
 				alive = false
 			}
-
-			//} else {
-			// TODO: Implement for consul backend; would it be needed ever?
 		}
 	}
 
@@ -239,6 +234,21 @@
 	return err
 }
 
+// DeleteWithPrefix removes items having prefix key
+func (b *Backend) DeleteWithPrefix(ctx context.Context, prefixKey string) error {
+	span, ctx := log.CreateChildSpan(ctx, "etcd-delete-with-prefix")
+	defer span.Finish()
+
+	formattedPath := b.makePath(ctx, prefixKey)
+	logger.Debugw(ctx, "deleting-prefix-key", log.Fields{"key": prefixKey, "path": formattedPath})
+
+	err := b.Client.DeleteWithPrefix(ctx, formattedPath)
+
+	b.updateLiveness(ctx, b.isErrorIndicatingAliveKvstore(ctx, err))
+
+	return err
+}
+
 // CreateWatch starts watching events for the specified key
 func (b *Backend) CreateWatch(ctx context.Context, key string, withPrefix bool) chan *kvstore.Event {
 	span, ctx := log.CreateChildSpan(ctx, "etcd-create-watch")
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/client.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/client.go
index 480d476..b35f1f3 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/client.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/client.go
@@ -21,8 +21,6 @@
 )
 
 const (
-	// Default timeout in seconds when making a kvstore request
-	defaultKVGetTimeout = 5 * time.Second
 	// Maximum channel buffer between publisher/subscriber goroutines
 	maxClientChannelBufferSize = 10
 )
@@ -80,6 +78,7 @@
 	Get(ctx context.Context, key string) (*KVPair, error)
 	Put(ctx context.Context, key string, value interface{}) error
 	Delete(ctx context.Context, key string) error
+	DeleteWithPrefix(ctx context.Context, prefixKey string) error
 	Reserve(ctx context.Context, key string, value interface{}, ttl time.Duration) (interface{}, error)
 	ReleaseReservation(ctx context.Context, key string) error
 	ReleaseAllReservations(ctx context.Context) error
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/consulclient.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/consulclient.go
deleted file mode 100644
index 2593608..0000000
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/consulclient.go
+++ /dev/null
@@ -1,512 +0,0 @@
-/*
- * Copyright 2018-present Open Networking Foundation
-
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
-
- * http://www.apache.org/licenses/LICENSE-2.0
-
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package kvstore
-
-import (
-	"bytes"
-	"context"
-	"errors"
-	log "github.com/opencord/voltha-lib-go/v4/pkg/log"
-	"sync"
-	"time"
-	//log "ciena.com/coordinator/common"
-	consulapi "github.com/hashicorp/consul/api"
-)
-
-type channelContextMap struct {
-	ctx     context.Context
-	channel chan *Event
-	cancel  context.CancelFunc
-}
-
-// ConsulClient represents the consul KV store client
-type ConsulClient struct {
-	session                *consulapi.Session
-	sessionID              string
-	consul                 *consulapi.Client
-	doneCh                 *chan int
-	keyReservations        map[string]interface{}
-	watchedChannelsContext map[string][]*channelContextMap
-	writeLock              sync.Mutex
-}
-
-// NewConsulClient returns a new client for the Consul KV store
-func NewConsulClient(ctx context.Context, addr string, timeout time.Duration) (*ConsulClient, error) {
-	config := consulapi.DefaultConfig()
-	config.Address = addr
-	config.WaitTime = timeout
-	consul, err := consulapi.NewClient(config)
-	if err != nil {
-		logger.Error(ctx, err)
-		return nil, err
-	}
-
-	doneCh := make(chan int, 1)
-	wChannelsContext := make(map[string][]*channelContextMap)
-	reservations := make(map[string]interface{})
-	return &ConsulClient{consul: consul, doneCh: &doneCh, watchedChannelsContext: wChannelsContext, keyReservations: reservations}, nil
-}
-
-// IsConnectionUp returns whether the connection to the Consul KV store is up
-func (c *ConsulClient) IsConnectionUp(ctx context.Context) bool {
-	logger.Error(ctx, "Unimplemented function")
-	return false
-}
-
-// List returns an array of key-value pairs with key as a prefix.  Timeout defines how long the function will
-// wait for a response
-func (c *ConsulClient) List(ctx context.Context, key string) (map[string]*KVPair, error) {
-
-	deadline, _ := ctx.Deadline()
-	kv := c.consul.KV()
-	var queryOptions consulapi.QueryOptions
-	// Substract current time from deadline to get the waitTime duration
-	queryOptions.WaitTime = time.Until(deadline)
-
-	// For now we ignore meta data
-	kvps, _, err := kv.List(key, &queryOptions)
-	if err != nil {
-		logger.Error(ctx, err)
-		return nil, err
-	}
-	m := make(map[string]*KVPair)
-	for _, kvp := range kvps {
-		m[string(kvp.Key)] = NewKVPair(string(kvp.Key), kvp.Value, string(kvp.Session), 0, -1)
-	}
-	return m, nil
-}
-
-// Get returns a key-value pair for a given key. Timeout defines how long the function will
-// wait for a response
-func (c *ConsulClient) Get(ctx context.Context, key string) (*KVPair, error) {
-
-	deadline, _ := ctx.Deadline()
-	kv := c.consul.KV()
-	var queryOptions consulapi.QueryOptions
-	// Substract current time from deadline to get the waitTime duration
-	queryOptions.WaitTime = time.Until(deadline)
-
-	// For now we ignore meta data
-	kvp, _, err := kv.Get(key, &queryOptions)
-	if err != nil {
-		logger.Error(ctx, err)
-		return nil, err
-	}
-	if kvp != nil {
-		return NewKVPair(string(kvp.Key), kvp.Value, string(kvp.Session), 0, -1), nil
-	}
-
-	return nil, nil
-}
-
-// Put writes a key-value pair to the KV store.  Value can only be a string or []byte since the consul API
-// accepts only a []byte as a value for a put operation. Timeout defines how long the function will
-// wait for a response
-func (c *ConsulClient) Put(ctx context.Context, key string, value interface{}) error {
-
-	// Validate that we can create a byte array from the value as consul API expects a byte array
-	var val []byte
-	var er error
-	if val, er = ToByte(value); er != nil {
-		logger.Error(ctx, er)
-		return er
-	}
-
-	// Create a key value pair
-	kvp := consulapi.KVPair{Key: key, Value: val}
-	kv := c.consul.KV()
-	var writeOptions consulapi.WriteOptions
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	_, err := kv.Put(&kvp, &writeOptions)
-	if err != nil {
-		logger.Error(ctx, err)
-		return err
-	}
-	return nil
-}
-
-// Delete removes a key from the KV store. Timeout defines how long the function will
-// wait for a response
-func (c *ConsulClient) Delete(ctx context.Context, key string) error {
-	kv := c.consul.KV()
-	var writeOptions consulapi.WriteOptions
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	_, err := kv.Delete(key, &writeOptions)
-	if err != nil {
-		logger.Error(ctx, err)
-		return err
-	}
-	return nil
-}
-
-func (c *ConsulClient) deleteSession(ctx context.Context) {
-	if c.sessionID != "" {
-		logger.Debug(ctx, "cleaning-up-session")
-		session := c.consul.Session()
-		_, err := session.Destroy(c.sessionID, nil)
-		if err != nil {
-			logger.Errorw(ctx, "error-cleaning-session", log.Fields{"session": c.sessionID, "error": err})
-		}
-	}
-	c.sessionID = ""
-	c.session = nil
-}
-
-func (c *ConsulClient) createSession(ctx context.Context, ttl time.Duration, retries int) (*consulapi.Session, string, error) {
-	session := c.consul.Session()
-	entry := &consulapi.SessionEntry{
-		Behavior: consulapi.SessionBehaviorDelete,
-		TTL:      ttl.String(),
-	}
-
-	for {
-		id, meta, err := session.Create(entry, nil)
-		if err != nil {
-			logger.Errorw(ctx, "create-session-error", log.Fields{"error": err})
-			if retries == 0 {
-				return nil, "", err
-			}
-		} else if meta.RequestTime == 0 {
-			logger.Errorw(ctx, "create-session-bad-meta-data", log.Fields{"meta-data": meta})
-			if retries == 0 {
-				return nil, "", errors.New("bad-meta-data")
-			}
-		} else if id == "" {
-			logger.Error(ctx, "create-session-nil-id")
-			if retries == 0 {
-				return nil, "", errors.New("ID-nil")
-			}
-		} else {
-			return session, id, nil
-		}
-		// If retry param is -1 we will retry indefinitely
-		if retries > 0 {
-			retries--
-		}
-		logger.Debug(ctx, "retrying-session-create-after-a-second-delay")
-		time.Sleep(time.Duration(1) * time.Second)
-	}
-}
-
-// Helper function to verify mostly whether the content of two interface types are the same.  Focus is []byte and
-// string types
-func isEqual(val1 interface{}, val2 interface{}) bool {
-	b1, err := ToByte(val1)
-	b2, er := ToByte(val2)
-	if err == nil && er == nil {
-		return bytes.Equal(b1, b2)
-	}
-	return val1 == val2
-}
-
-// Reserve is invoked to acquire a key and set it to a given value. Value can only be a string or []byte since
-// the consul API accepts only a []byte.  Timeout defines how long the function will wait for a response.  TTL
-// defines how long that reservation is valid.  When TTL expires the key is unreserved by the KV store itself.
-// If the key is acquired then the value returned will be the value passed in.  If the key is already acquired
-// then the value assigned to that key will be returned.
-func (c *ConsulClient) Reserve(ctx context.Context, key string, value interface{}, ttl time.Duration) (interface{}, error) {
-
-	// Validate that we can create a byte array from the value as consul API expects a byte array
-	var val []byte
-	var er error
-	if val, er = ToByte(value); er != nil {
-		logger.Error(ctx, er)
-		return nil, er
-	}
-
-	// Cleanup any existing session and recreate new ones.  A key is reserved against a session
-	if c.sessionID != "" {
-		c.deleteSession(ctx)
-	}
-
-	// Clear session if reservation is not successful
-	reservationSuccessful := false
-	defer func() {
-		if !reservationSuccessful {
-			logger.Debug(ctx, "deleting-session")
-			c.deleteSession(ctx)
-		}
-	}()
-
-	session, sessionID, err := c.createSession(ctx, ttl, -1)
-	if err != nil {
-		logger.Errorw(ctx, "no-session-created", log.Fields{"error": err})
-		return "", errors.New("no-session-created")
-	}
-	logger.Debugw(ctx, "session-created", log.Fields{"session-id": sessionID})
-	c.sessionID = sessionID
-	c.session = session
-
-	// Try to grap the Key using the session
-	kv := c.consul.KV()
-	kvp := consulapi.KVPair{Key: key, Value: val, Session: c.sessionID}
-	result, _, err := kv.Acquire(&kvp, nil)
-	if err != nil {
-		logger.Errorw(ctx, "error-acquiring-keys", log.Fields{"error": err})
-		return nil, err
-	}
-
-	logger.Debugw(ctx, "key-acquired", log.Fields{"key": key, "status": result})
-
-	// Irrespective whether we were successful in acquiring the key, let's read it back and see if it's us.
-	m, err := c.Get(ctx, key)
-	if err != nil {
-		return nil, err
-	}
-	if m != nil {
-		logger.Debugw(ctx, "response-received", log.Fields{"key": m.Key, "m.value": string(m.Value.([]byte)), "value": value})
-		if m.Key == key && isEqual(m.Value, value) {
-			// My reservation is successful - register it.  For now, support is only for 1 reservation per key
-			// per session.
-			reservationSuccessful = true
-			c.writeLock.Lock()
-			c.keyReservations[key] = m.Value
-			c.writeLock.Unlock()
-			return m.Value, nil
-		}
-		// My reservation has failed.  Return the owner of that key
-		return m.Value, nil
-	}
-	return nil, nil
-}
-
-// ReleaseAllReservations releases all key reservations previously made (using Reserve API)
-func (c *ConsulClient) ReleaseAllReservations(ctx context.Context) error {
-	kv := c.consul.KV()
-	var kvp consulapi.KVPair
-	var result bool
-	var err error
-
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-
-	for key, value := range c.keyReservations {
-		kvp = consulapi.KVPair{Key: key, Value: value.([]byte), Session: c.sessionID}
-		result, _, err = kv.Release(&kvp, nil)
-		if err != nil {
-			logger.Errorw(ctx, "cannot-release-reservation", log.Fields{"key": key, "error": err})
-			return err
-		}
-		if !result {
-			logger.Errorw(ctx, "cannot-release-reservation", log.Fields{"key": key})
-		}
-		delete(c.keyReservations, key)
-	}
-	return nil
-}
-
-// ReleaseReservation releases reservation for a specific key.
-func (c *ConsulClient) ReleaseReservation(ctx context.Context, key string) error {
-	var ok bool
-	var reservedValue interface{}
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	if reservedValue, ok = c.keyReservations[key]; !ok {
-		return errors.New("key-not-reserved:" + key)
-	}
-	// Release the reservation
-	kv := c.consul.KV()
-	kvp := consulapi.KVPair{Key: key, Value: reservedValue.([]byte), Session: c.sessionID}
-
-	result, _, er := kv.Release(&kvp, nil)
-	if er != nil {
-		return er
-	}
-	// Remove that key entry on success
-	if result {
-		delete(c.keyReservations, key)
-		return nil
-	}
-	return errors.New("key-cannot-be-unreserved")
-}
-
-// RenewReservation renews a reservation.  A reservation will go stale after the specified TTL (Time To Live)
-// period specified when reserving the key
-func (c *ConsulClient) RenewReservation(ctx context.Context, key string) error {
-	// In the case of Consul, renew reservation of a reserve key only require renewing the client session.
-
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-
-	// Verify the key was reserved
-	if _, ok := c.keyReservations[key]; !ok {
-		return errors.New("key-not-reserved")
-	}
-
-	if c.session == nil {
-		return errors.New("no-session-exist")
-	}
-
-	var writeOptions consulapi.WriteOptions
-	if _, _, err := c.session.Renew(c.sessionID, &writeOptions); err != nil {
-		return err
-	}
-	return nil
-}
-
-// Watch provides the watch capability on a given key.  It returns a channel onto which the callee needs to
-// listen to receive Events.
-func (c *ConsulClient) Watch(ctx context.Context, key string, withPrefix bool) chan *Event {
-
-	// Create a new channel
-	ch := make(chan *Event, maxClientChannelBufferSize)
-
-	// Create a context to track this request
-	watchContext, cFunc := context.WithCancel(context.Background())
-
-	// Save the channel and context reference for later
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	ccm := channelContextMap{channel: ch, ctx: watchContext, cancel: cFunc}
-	c.watchedChannelsContext[key] = append(c.watchedChannelsContext[key], &ccm)
-
-	// Launch a go routine to listen for updates
-	go c.listenForKeyChange(watchContext, key, ch)
-
-	return ch
-}
-
-// CloseWatch closes a specific watch. Both the key and the channel are required when closing a watch as there
-// may be multiple listeners on the same key.  The previously created channel serves as a key
-func (c *ConsulClient) CloseWatch(ctx context.Context, key string, ch chan *Event) {
-	// First close the context
-	var ok bool
-	var watchedChannelsContexts []*channelContextMap
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	if watchedChannelsContexts, ok = c.watchedChannelsContext[key]; !ok {
-		logger.Errorw(ctx, "key-has-no-watched-context-or-channel", log.Fields{"key": key})
-		return
-	}
-	// Look for the channels
-	var pos = -1
-	for i, chCtxMap := range watchedChannelsContexts {
-		if chCtxMap.channel == ch {
-			logger.Debug(ctx, "channel-found")
-			chCtxMap.cancel()
-			//close the channel
-			close(ch)
-			pos = i
-			break
-		}
-	}
-	// Remove that entry if present
-	if pos >= 0 {
-		c.watchedChannelsContext[key] = append(c.watchedChannelsContext[key][:pos], c.watchedChannelsContext[key][pos+1:]...)
-	}
-	logger.Debugw(ctx, "watched-channel-exiting", log.Fields{"key": key, "channel": c.watchedChannelsContext[key]})
-}
-
-func (c *ConsulClient) isKVEqual(kv1 *consulapi.KVPair, kv2 *consulapi.KVPair) bool {
-	if (kv1 == nil) && (kv2 == nil) {
-		return true
-	} else if (kv1 == nil) || (kv2 == nil) {
-		return false
-	}
-	// Both the KV should be non-null here
-	if kv1.Key != kv2.Key ||
-		!bytes.Equal(kv1.Value, kv2.Value) ||
-		kv1.Session != kv2.Session ||
-		kv1.LockIndex != kv2.LockIndex ||
-		kv1.ModifyIndex != kv2.ModifyIndex {
-		return false
-	}
-	return true
-}
-
-func (c *ConsulClient) listenForKeyChange(ctx context.Context, key string, ch chan *Event) {
-	logger.Debugw(ctx, "start-watching-channel", log.Fields{"key": key, "channel": ch})
-
-	defer c.CloseWatch(ctx, key, ch)
-	kv := c.consul.KV()
-	var queryOptions consulapi.QueryOptions
-	queryOptions.WaitTime = defaultKVGetTimeout
-
-	// Get the existing value, if any
-	previousKVPair, meta, err := kv.Get(key, &queryOptions)
-	if err != nil {
-		logger.Debug(ctx, err)
-	}
-	lastIndex := meta.LastIndex
-
-	// Wait for change.  Push any change onto the channel and keep waiting for new update
-	//var waitOptions consulapi.QueryOptions
-	var pair *consulapi.KVPair
-	//watchContext, _ := context.WithCancel(context.Background())
-	waitOptions := queryOptions.WithContext(ctx)
-	for {
-		//waitOptions = consulapi.QueryOptions{WaitIndex: lastIndex}
-		waitOptions.WaitIndex = lastIndex
-		pair, meta, err = kv.Get(key, waitOptions)
-		select {
-		case <-ctx.Done():
-			logger.Debug(ctx, "done-event-received-exiting")
-			return
-		default:
-			if err != nil {
-				logger.Warnw(ctx, "error-from-watch", log.Fields{"error": err})
-				ch <- NewEvent(CONNECTIONDOWN, key, []byte(""), -1)
-			} else {
-				logger.Debugw(ctx, "index-state", log.Fields{"lastindex": lastIndex, "newindex": meta.LastIndex, "key": key})
-			}
-		}
-		if err != nil {
-			logger.Debug(ctx, err)
-			// On error, block for 10 milliseconds to prevent endless loop
-			time.Sleep(10 * time.Millisecond)
-		} else if meta.LastIndex <= lastIndex {
-			logger.Info(ctx, "no-index-change-or-negative")
-		} else {
-			logger.Debugw(ctx, "update-received", log.Fields{"pair": pair})
-			if pair == nil {
-				ch <- NewEvent(DELETE, key, []byte(""), -1)
-			} else if !c.isKVEqual(pair, previousKVPair) {
-				// Push the change onto the channel if the data has changed
-				// For now just assume it's a PUT change
-				logger.Debugw(ctx, "pair-details", log.Fields{"session": pair.Session, "key": pair.Key, "value": pair.Value})
-				ch <- NewEvent(PUT, pair.Key, pair.Value, -1)
-			}
-			previousKVPair = pair
-			lastIndex = meta.LastIndex
-		}
-	}
-}
-
-// Close closes the KV store client
-func (c *ConsulClient) Close(ctx context.Context) {
-	var writeOptions consulapi.WriteOptions
-	// Inform any goroutine it's time to say goodbye.
-	c.writeLock.Lock()
-	defer c.writeLock.Unlock()
-	if c.doneCh != nil {
-		close(*c.doneCh)
-	}
-
-	// Clear the sessionID
-	if _, err := c.consul.Session().Destroy(c.sessionID, &writeOptions); err != nil {
-		logger.Errorw(ctx, "error-closing-client", log.Fields{"error": err})
-	}
-}
-
-func (c *ConsulClient) AcquireLock(ctx context.Context, lockName string, timeout time.Duration) error {
-	return nil
-}
-
-func (c *ConsulClient) ReleaseLock(lockName string) error {
-	return nil
-}
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/etcdclient.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/etcdclient.go
index aa5adbf..868b301 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/etcdclient.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/etcdclient.go
@@ -157,6 +157,17 @@
 	return nil
 }
 
+func (c *EtcdClient) DeleteWithPrefix(ctx context.Context, prefixKey string) error {
+
+	//delete the prefix
+	if _, err := c.ectdAPI.Delete(ctx, prefixKey, v3Client.WithPrefix()); err != nil {
+		logger.Errorw(ctx, "failed-to-delete-prefix-key", log.Fields{"key": prefixKey, "error": err})
+		return err
+	}
+	logger.Debugw(ctx, "key(s)-deleted", log.Fields{"key": prefixKey})
+	return nil
+}
+
 // Reserve is invoked to acquire a key and set it to a given value. Value can only be a string or []byte since
 // the etcd API accepts only a string.  Timeout defines how long the function will wait for a response.  TTL
 // defines how long that reservation is valid.  When TTL expires the key is unreserved by the KV store itself.
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/kvutils.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/kvutils.go
index 64e7d30..70bd977 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/kvutils.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/db/kvstore/kvutils.go
@@ -15,7 +15,10 @@
  */
 package kvstore
 
-import "fmt"
+import (
+	"bytes"
+	"fmt"
+)
 
 // ToString converts an interface value to a string.  The interface should either be of
 // a string type or []byte.  Otherwise, an error is returned.
@@ -42,3 +45,14 @@
 		return nil, fmt.Errorf("unexpected-type-%T", t)
 	}
 }
+
+// Helper function to verify mostly whether the content of two interface types are the same.  Focus is []byte and
+// string types
+func isEqual(val1 interface{}, val2 interface{}) bool {
+	b1, err := ToByte(val1)
+	b2, er := ToByte(val2)
+	if err == nil && er == nil {
+		return bytes.Equal(b1, b2)
+	}
+	return val1 == val2
+}
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/events/events_proxy.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/events/events_proxy.go
index a4b12f7..c4014ee 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/events/events_proxy.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/events/events_proxy.go
@@ -78,6 +78,8 @@
 	header.Category = category
 	if subCategory != nil {
 		header.SubCategory = *subCategory
+	} else {
+		header.SubCategory = voltha.EventSubCategory_NONE
 	}
 	header.Type = eventType
 	header.TypeVersion = eventif.EventTypeVersion
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/ponresourcemanager/ponresourcemanager.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/ponresourcemanager/ponresourcemanager.go
index 408936b..415ce21 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/ponresourcemanager/ponresourcemanager.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/ponresourcemanager/ponresourcemanager.go
@@ -112,8 +112,11 @@
 	FLOW_ID_RESOURCE_MAP_PATH = "{%s}/{%s}/flow_ids"
 
 	//Flow Id info: Use to store more metadata associated with the flow_id
-	//Format: <device_id>/<(pon_intf_id, onu_id)>/flow_id_info/<flow_id>
-	FLOW_ID_INFO_PATH = "{%s}/{%s}/flow_id_info/{%d}"
+	FLOW_ID_INFO_PATH_PREFIX = "{%s}/flow_id_info"
+	//Format: <device_id>/flow_id_info/<(pon_intf_id, onu_id)>
+	FLOW_ID_INFO_PATH_INTF_ONU_PREFIX = "{%s}/flow_id_info/{%s}"
+	//Format: <device_id>/flow_id_info/<(pon_intf_id, onu_id)><flow_id>
+	FLOW_ID_INFO_PATH = FLOW_ID_INFO_PATH_PREFIX + "/{%s}/{%d}"
 
 	//path on the kvstore to store onugem info map
 	//format: <device-id>/onu_gem_info/<intfid>
@@ -140,7 +143,7 @@
 	Technology       string
 	DeviceType       string
 	DeviceID         string
-	Backend          string // ETCD, or consul
+	Backend          string // ETCD only currently
 	Address          string // address of the KV store
 	OLTModel         string
 	KVStore          *db.Backend
@@ -159,8 +162,6 @@
 func newKVClient(ctx context.Context, storeType string, address string, timeout time.Duration) (kvstore.Client, error) {
 	logger.Infow(ctx, "kv-store-type", log.Fields{"store": storeType})
 	switch storeType {
-	case "consul":
-		return kvstore.NewConsulClient(ctx, address, timeout)
 	case "etcd":
 		return kvstore.NewEtcdClient(ctx, address, timeout, log.WarnLevel)
 	}
@@ -1036,6 +1037,20 @@
 	return true
 }
 
+func (PONRMgr *PONResourceManager) RemoveAllFlowIDInfo(ctx context.Context, IntfONUID string) bool {
+	/*
+	    Remove flow_id_info details configured for the ONU.
+	   :param pon_intf_onu_id: reference of PON interface id and onu id
+	*/
+	Path := fmt.Sprintf(FLOW_ID_INFO_PATH_INTF_ONU_PREFIX, PONRMgr.DeviceID, IntfONUID)
+
+	if err := PONRMgr.KVStore.DeleteWithPrefix(ctx, Path); err != nil {
+		logger.Errorf(ctx, "Falied to remove resource %s", Path)
+		return false
+	}
+	return true
+}
+
 func (PONRMgr *PONResourceManager) UpdateAllocIdsForOnu(ctx context.Context, IntfONUID string, AllocIDs []uint32) error {
 	/*
 	   Update currently configured alloc ids for given pon_intf_onu_id
diff --git a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/techprofile/tech_profile.go b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/techprofile/tech_profile.go
index e21de45..7609e09 100644
--- a/vendor/github.com/opencord/voltha-lib-go/v4/pkg/techprofile/tech_profile.go
+++ b/vendor/github.com/opencord/voltha-lib-go/v4/pkg/techprofile/tech_profile.go
@@ -411,8 +411,6 @@
 
 	logger.Infow(ctx, "kv-store", log.Fields{"storeType": storeType, "address": address})
 	switch storeType {
-	case "consul":
-		return kvstore.NewConsulClient(ctx, address, timeout)
 	case "etcd":
 		return kvstore.NewEtcdClient(ctx, address, timeout, log.WarnLevel)
 	}
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/common/common.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/common/common.pb.go
index 7bfcb33..0956330 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/common/common.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/common/common.pb.go
@@ -165,21 +165,18 @@
 	OperationResp_OPERATION_SUCCESS     OperationResp_OperationReturnCode = 0
 	OperationResp_OPERATION_FAILURE     OperationResp_OperationReturnCode = 1
 	OperationResp_OPERATION_UNSUPPORTED OperationResp_OperationReturnCode = 2
-	OperationResp_OPERATION_IN_PROGRESS OperationResp_OperationReturnCode = 3
 )
 
 var OperationResp_OperationReturnCode_name = map[int32]string{
 	0: "OPERATION_SUCCESS",
 	1: "OPERATION_FAILURE",
 	2: "OPERATION_UNSUPPORTED",
-	3: "OPERATION_IN_PROGRESS",
 }
 
 var OperationResp_OperationReturnCode_value = map[string]int32{
 	"OPERATION_SUCCESS":     0,
 	"OPERATION_FAILURE":     1,
 	"OPERATION_UNSUPPORTED": 2,
-	"OPERATION_IN_PROGRESS": 3,
 }
 
 func (x OperationResp_OperationReturnCode) String() string {
@@ -599,43 +596,43 @@
 func init() { proto.RegisterFile("voltha_protos/common.proto", fileDescriptor_c2e3fd231961e826) }
 
 var fileDescriptor_c2e3fd231961e826 = []byte{
-	// 606 bytes of a gzipped FileDescriptorProto
-	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x53, 0x5d, 0x4f, 0xdb, 0x30,
-	0x14, 0x6d, 0x9b, 0x96, 0xd1, 0x5b, 0x1a, 0x32, 0x03, 0x53, 0x87, 0x26, 0xad, 0xca, 0x0b, 0x6c,
-	0x62, 0xad, 0xc4, 0x78, 0xdd, 0x43, 0x48, 0xbc, 0xce, 0x02, 0x9c, 0xc8, 0x49, 0x8a, 0xe0, 0xa5,
-	0x0a, 0x8d, 0x29, 0x91, 0x68, 0x1c, 0x25, 0x2e, 0x12, 0x7f, 0x7b, 0xbf, 0x60, 0xb2, 0x53, 0xbe,
-	0x26, 0x5e, 0x12, 0x9f, 0x7b, 0x4e, 0xee, 0xf1, 0x3d, 0x8e, 0x61, 0xff, 0x41, 0xdc, 0xcb, 0xbb,
-	0x64, 0x56, 0x94, 0x42, 0x8a, 0x6a, 0x3c, 0x17, 0xcb, 0xa5, 0xc8, 0x47, 0x1a, 0xa1, 0x8d, 0x1a,
-	0xd9, 0xbb, 0xd0, 0x22, 0x1e, 0x32, 0xa1, 0x95, 0xa5, 0x83, 0xe6, 0xb0, 0x79, 0xd8, 0x65, 0xad,
-	0x2c, 0xb5, 0x0f, 0xc0, 0x20, 0x5e, 0x85, 0x86, 0xd0, 0xc9, 0x24, 0x5f, 0x56, 0x83, 0xe6, 0xd0,
-	0x38, 0xec, 0x1d, 0xc3, 0x68, 0xdd, 0x82, 0x78, 0xac, 0x26, 0xec, 0x3b, 0x00, 0x27, 0x5d, 0x66,
-	0x79, 0x28, 0x13, 0xc9, 0xed, 0x6b, 0xe8, 0x44, 0x8f, 0x05, 0xaf, 0x50, 0x0f, 0x3e, 0xc4, 0xf4,
-	0x8c, 0xfa, 0x97, 0xd4, 0x6a, 0x20, 0x04, 0x66, 0xc0, 0x70, 0xc0, 0xfc, 0x29, 0x09, 0x89, 0x4f,
-	0xb1, 0x67, 0x35, 0x95, 0x00, 0x53, 0xe7, 0xf4, 0x1c, 0x7b, 0x56, 0x0b, 0x6d, 0xc1, 0xa6, 0x47,
-	0xc2, 0x1a, 0x19, 0x68, 0x0f, 0x3e, 0x7a, 0xfe, 0x25, 0x3d, 0xf7, 0x1d, 0x8f, 0xd0, 0xc9, 0x8c,
-	0x5c, 0x38, 0x13, 0x6c, 0xb5, 0xed, 0x05, 0x80, 0x5f, 0xf0, 0x52, 0x19, 0xad, 0x2a, 0xfb, 0xea,
-	0x5d, 0x27, 0x13, 0xc0, 0x23, 0xa1, 0xeb, 0x4f, 0x31, 0xd3, 0x2e, 0x26, 0x80, 0xe3, 0x46, 0x64,
-	0xea, 0x44, 0x84, 0x4e, 0xac, 0x96, 0x12, 0x47, 0x38, 0xd4, 0xc0, 0x40, 0x00, 0x1b, 0x9a, 0xc4,
-	0x56, 0x5b, 0xad, 0x7f, 0x3b, 0x44, 0xf9, 0x77, 0x6c, 0x0c, 0x7d, 0x57, 0xe4, 0x39, 0x9f, 0xcb,
-	0xb5, 0xd7, 0xc9, 0xbb, 0x5e, 0xdb, 0xd0, 0x8b, 0x29, 0xc3, 0x8e, 0xfb, 0x47, 0x6d, 0xdc, 0x6a,
-	0xa2, 0x3e, 0x74, 0x5f, 0x60, 0xcb, 0xfe, 0xdb, 0x84, 0xbe, 0xda, 0x70, 0x22, 0x33, 0x91, 0x33,
-	0x5e, 0x15, 0xe8, 0x17, 0xb4, 0xe7, 0x22, 0xe5, 0x3a, 0x66, 0xf3, 0xf8, 0xdb, 0x53, 0x98, 0x6f,
-	0x44, 0xaf, 0x91, 0x5c, 0x95, 0xb9, 0x2b, 0x52, 0xce, 0xf4, 0x67, 0xe8, 0x00, 0xb6, 0x93, 0x34,
-	0xcd, 0x14, 0x97, 0xdc, 0xcf, 0xb2, 0xfc, 0x56, 0x0c, 0x5a, 0xfa, 0xc0, 0xcc, 0x97, 0x32, 0xc9,
-	0x6f, 0x85, 0xfd, 0x08, 0x3b, 0xef, 0x74, 0x51, 0xb9, 0xfa, 0x01, 0x66, 0x4e, 0x44, 0x7c, 0x3a,
-	0x0b, 0x63, 0xd7, 0xc5, 0x61, 0x68, 0x35, 0xde, 0x96, 0x55, 0x08, 0x31, 0x53, 0xd3, 0x7c, 0x86,
-	0xbd, 0x97, 0x72, 0x4c, 0xc3, 0x38, 0x08, 0x7c, 0x16, 0xe9, 0xe3, 0x7a, 0x43, 0x11, 0x3a, 0x0b,
-	0x98, 0x3f, 0x61, 0xaa, 0x99, 0x61, 0x1f, 0x41, 0x77, 0x9a, 0xdc, 0xaf, 0xb8, 0xca, 0xcb, 0xfe,
-	0x0a, 0x6d, 0xf5, 0x46, 0x5d, 0xe8, 0xe0, 0x8b, 0x20, 0xba, 0xb2, 0x1a, 0xeb, 0x93, 0x8e, 0x1c,
-	0xea, 0x62, 0xab, 0x69, 0x53, 0x30, 0xb5, 0x3a, 0x2c, 0xf8, 0x3c, 0xbb, 0xcd, 0x78, 0xf9, 0xff,
-	0x7f, 0x88, 0x8e, 0xa0, 0xf3, 0xa0, 0x14, 0x7a, 0x52, 0xf3, 0xf8, 0xd3, 0x53, 0x66, 0xcf, 0x26,
-	0x23, 0xf5, 0x60, 0xb5, 0xc8, 0x96, 0xb0, 0x55, 0xcf, 0xab, 0xe9, 0x0a, 0x59, 0x60, 0x84, 0x5c,
-	0xea, 0x76, 0x7d, 0xa6, 0x96, 0x68, 0x08, 0xbd, 0x38, 0xaf, 0x56, 0x45, 0x21, 0x4a, 0xc9, 0x53,
-	0xdd, 0xb5, 0xcf, 0x5e, 0x97, 0xd0, 0x2e, 0x74, 0x70, 0x59, 0x8a, 0x72, 0x60, 0x68, 0xae, 0x06,
-	0x68, 0x1f, 0x36, 0xbd, 0xac, 0x92, 0x49, 0x3e, 0xe7, 0x83, 0xb6, 0x26, 0x9e, 0xf1, 0xf7, 0x2f,
-	0xb0, 0x15, 0xf1, 0x4a, 0x5e, 0x88, 0x94, 0x9f, 0xf1, 0xc7, 0x4a, 0xcd, 0x98, 0x14, 0xd9, 0x4c,
-	0xf2, 0x4a, 0x5a, 0x8d, 0x53, 0x0c, 0x3b, 0xa2, 0x5c, 0x8c, 0x44, 0xc1, 0xf3, 0xb9, 0x28, 0xd3,
-	0x51, 0x7d, 0x25, 0xaf, 0x47, 0x8b, 0x4c, 0xde, 0xad, 0x6e, 0xd4, 0x3c, 0xe3, 0x27, 0x6e, 0x5c,
-	0x73, 0x3f, 0xd6, 0xd7, 0xf5, 0xe1, 0x64, 0xbc, 0x10, 0xeb, 0x4b, 0x7b, 0xb3, 0xa1, 0x8b, 0x3f,
-	0xff, 0x05, 0x00, 0x00, 0xff, 0xff, 0x27, 0x0a, 0x9c, 0xc8, 0xd3, 0x03, 0x00, 0x00,
+	// 598 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x53, 0x5f, 0x4f, 0xdb, 0x3e,
+	0x14, 0x6d, 0xd2, 0x96, 0x1f, 0xbd, 0xa5, 0x21, 0x3f, 0x03, 0x53, 0x87, 0x26, 0xad, 0xca, 0x0b,
+	0x6c, 0x62, 0xad, 0xc4, 0x78, 0xdd, 0x43, 0x48, 0x3c, 0x66, 0x01, 0x4e, 0xe5, 0x24, 0x45, 0xf0,
+	0xb0, 0x2a, 0x34, 0xa6, 0x44, 0xa2, 0x71, 0x94, 0xb8, 0x48, 0x7c, 0xd2, 0x7d, 0x9d, 0xc9, 0x4e,
+	0xf9, 0x37, 0xf5, 0x25, 0xf1, 0xb9, 0xe7, 0xe4, 0x1e, 0xdf, 0xe3, 0x18, 0xf6, 0x1f, 0xc5, 0x83,
+	0xbc, 0x4f, 0xa6, 0x45, 0x29, 0xa4, 0xa8, 0x46, 0x33, 0xb1, 0x58, 0x88, 0x7c, 0xa8, 0x11, 0xda,
+	0xa8, 0x91, 0xb3, 0x0b, 0x26, 0xf1, 0x91, 0x05, 0x66, 0x96, 0xf6, 0x8d, 0x81, 0x71, 0xd8, 0x61,
+	0x66, 0x96, 0x3a, 0x07, 0xd0, 0x24, 0x7e, 0x85, 0x06, 0xd0, 0xce, 0x24, 0x5f, 0x54, 0x7d, 0x63,
+	0xd0, 0x3c, 0xec, 0x1e, 0xc3, 0x70, 0xd5, 0x82, 0xf8, 0xac, 0x26, 0x9c, 0x7b, 0x00, 0x37, 0x5d,
+	0x64, 0x79, 0x28, 0x13, 0xc9, 0x9d, 0x1b, 0x68, 0x47, 0x4f, 0x05, 0xaf, 0x50, 0x17, 0xfe, 0x8b,
+	0xe9, 0x39, 0x0d, 0xae, 0xa8, 0xdd, 0x40, 0x08, 0xac, 0x31, 0xc3, 0x63, 0x16, 0x4c, 0x48, 0x48,
+	0x02, 0x8a, 0x7d, 0xdb, 0x50, 0x02, 0x4c, 0xdd, 0xd3, 0x0b, 0xec, 0xdb, 0x26, 0xda, 0x82, 0x4d,
+	0x9f, 0x84, 0x35, 0x6a, 0xa2, 0x3d, 0xf8, 0xdf, 0x0f, 0xae, 0xe8, 0x45, 0xe0, 0xfa, 0x84, 0x9e,
+	0x4d, 0xc9, 0xa5, 0x7b, 0x86, 0xed, 0x96, 0x33, 0x07, 0x08, 0x0a, 0x5e, 0x2a, 0xa3, 0x65, 0xe5,
+	0x5c, 0xaf, 0x75, 0xb2, 0x00, 0x7c, 0x12, 0x7a, 0xc1, 0x04, 0x33, 0xed, 0x62, 0x01, 0xb8, 0x5e,
+	0x44, 0x26, 0x6e, 0x44, 0xe8, 0x99, 0x6d, 0x2a, 0x71, 0x84, 0x43, 0x0d, 0x9a, 0x08, 0x60, 0x43,
+	0x93, 0xd8, 0x6e, 0xa9, 0xf5, 0x4f, 0x97, 0x28, 0xff, 0xb6, 0x83, 0xa1, 0xe7, 0x89, 0x3c, 0xe7,
+	0x33, 0xb9, 0xf2, 0x3a, 0x59, 0xeb, 0xb5, 0x0d, 0xdd, 0x98, 0x32, 0xec, 0x7a, 0xbf, 0xd4, 0xc6,
+	0x6d, 0x03, 0xf5, 0xa0, 0xf3, 0x0a, 0x4d, 0xe7, 0x8f, 0x01, 0x3d, 0xb5, 0xe1, 0x44, 0x66, 0x22,
+	0x67, 0xbc, 0x2a, 0xd0, 0x0f, 0x68, 0xcd, 0x44, 0xca, 0x75, 0xcc, 0xd6, 0xf1, 0x97, 0xe7, 0x30,
+	0xdf, 0x89, 0xde, 0x22, 0xb9, 0x2c, 0x73, 0x4f, 0xa4, 0x9c, 0xe9, 0xcf, 0xd0, 0x01, 0x6c, 0x27,
+	0x69, 0x9a, 0x29, 0x2e, 0x79, 0x98, 0x66, 0xf9, 0x9d, 0xe8, 0x9b, 0xfa, 0xc0, 0xac, 0xd7, 0x32,
+	0xc9, 0xef, 0x84, 0xf3, 0x1b, 0x76, 0xd6, 0x74, 0x51, 0xb9, 0x06, 0x63, 0xcc, 0xdc, 0x88, 0x04,
+	0x74, 0x1a, 0xc6, 0x9e, 0x87, 0xc3, 0xd0, 0x6e, 0xbc, 0x2f, 0xab, 0x10, 0x62, 0xa6, 0xa6, 0xf9,
+	0x08, 0x7b, 0xaf, 0xe5, 0x98, 0x86, 0xf1, 0x78, 0x1c, 0xb0, 0x48, 0x1d, 0x97, 0x73, 0x04, 0x9d,
+	0x49, 0xf2, 0xb0, 0xe4, 0x2a, 0x14, 0xe7, 0x33, 0xb4, 0xd4, 0x1b, 0x75, 0xa0, 0x8d, 0x2f, 0xc7,
+	0xd1, 0xb5, 0xdd, 0x58, 0x1d, 0x67, 0xe4, 0x52, 0x0f, 0xdb, 0x86, 0x43, 0xc1, 0xd2, 0xea, 0xb0,
+	0xe0, 0xb3, 0xec, 0x2e, 0xe3, 0xe5, 0xbf, 0x3f, 0x1b, 0x3a, 0x82, 0xf6, 0xa3, 0x52, 0xe8, 0x71,
+	0xac, 0xe3, 0x0f, 0xcf, 0xc1, 0xbc, 0x98, 0x0c, 0xd5, 0x83, 0xd5, 0x22, 0x47, 0xc2, 0x56, 0x3d,
+	0x94, 0xa6, 0x2b, 0x64, 0x43, 0x33, 0xe4, 0x52, 0xb7, 0xeb, 0x31, 0xb5, 0x44, 0x03, 0xe8, 0xc6,
+	0x79, 0xb5, 0x2c, 0x0a, 0x51, 0x4a, 0x9e, 0xea, 0xae, 0x3d, 0xf6, 0xb6, 0x84, 0x76, 0xa1, 0x8d,
+	0xcb, 0x52, 0x94, 0xfd, 0xa6, 0xe6, 0x6a, 0x80, 0xf6, 0x61, 0xd3, 0xcf, 0x2a, 0x99, 0xe4, 0x33,
+	0xde, 0x6f, 0x69, 0xe2, 0x05, 0x7f, 0xfd, 0x04, 0x5b, 0x11, 0xaf, 0xe4, 0xa5, 0x48, 0xf9, 0x39,
+	0x7f, 0xaa, 0xd4, 0x8c, 0x49, 0x91, 0x4d, 0x25, 0xaf, 0xa4, 0xdd, 0x38, 0xc5, 0xb0, 0x23, 0xca,
+	0xf9, 0x50, 0x14, 0x3c, 0x9f, 0x89, 0x32, 0x1d, 0xd6, 0xf7, 0xee, 0x66, 0x38, 0xcf, 0xe4, 0xfd,
+	0xf2, 0x56, 0xcd, 0x33, 0x7a, 0xe6, 0x46, 0x35, 0xf7, 0x6d, 0x75, 0x27, 0x1f, 0x4f, 0x46, 0x73,
+	0xb1, 0xba, 0x99, 0xb7, 0x1b, 0xba, 0xf8, 0xfd, 0x6f, 0x00, 0x00, 0x00, 0xff, 0xff, 0x7d, 0x32,
+	0x70, 0x38, 0xb8, 0x03, 0x00, 0x00,
 }
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/inter_container/inter_container.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/inter_container/inter_container.pb.go
index 051a705..752eecb 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/inter_container/inter_container.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/inter_container/inter_container.pb.go
@@ -104,7 +104,6 @@
 const OperationResp_OPERATION_SUCCESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_SUCCESS)
 const OperationResp_OPERATION_FAILURE = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_FAILURE)
 const OperationResp_OPERATION_UNSUPPORTED = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_UNSUPPORTED)
-const OperationResp_OPERATION_IN_PROGRESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_IN_PROGRESS)
 
 // ValueType_Type from public import voltha_protos/common.proto
 type ValueType_Type = common.ValueType_Type
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/openolt/openolt.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/openolt/openolt.pb.go
index 1989289..5122fe1 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/openolt/openolt.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/openolt/openolt.pb.go
@@ -190,7 +190,6 @@
 const OperationResp_OPERATION_SUCCESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_SUCCESS)
 const OperationResp_OPERATION_FAILURE = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_FAILURE)
 const OperationResp_OPERATION_UNSUPPORTED = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_UNSUPPORTED)
-const OperationResp_OPERATION_IN_PROGRESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_IN_PROGRESS)
 
 // ValueType_Type from public import voltha_protos/common.proto
 type ValueType_Type = common.ValueType_Type
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/device.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/device.pb.go
index 6a4bac4..2499fd1 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/device.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/device.pb.go
@@ -7,7 +7,6 @@
 	fmt "fmt"
 	proto "github.com/golang/protobuf/proto"
 	any "github.com/golang/protobuf/ptypes/any"
-	timestamp "github.com/golang/protobuf/ptypes/timestamp"
 	common "github.com/opencord/voltha-protos/v4/go/common"
 	openflow_13 "github.com/opencord/voltha-protos/v4/go/openflow_13"
 	math "math"
@@ -231,7 +230,7 @@
 }
 
 func (SimulateAlarmRequest_OperationType) EnumDescriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{18, 0}
+	return fileDescriptor_200940f73d155856, []int{13, 0}
 }
 
 // A Device Type
@@ -1142,348 +1141,6 @@
 	return nil
 }
 
-// A complete device state
-type DeviceState struct {
-	AdminState           common.AdminState_Types    `protobuf:"varint,1,opt,name=admin_state,json=adminState,proto3,enum=common.AdminState_Types" json:"admin_state,omitempty"`
-	OperStatus           common.OperStatus_Types    `protobuf:"varint,2,opt,name=oper_status,json=operStatus,proto3,enum=common.OperStatus_Types" json:"oper_status,omitempty"`
-	ConnectStatus        common.ConnectStatus_Types `protobuf:"varint,3,opt,name=connect_status,json=connectStatus,proto3,enum=common.ConnectStatus_Types" json:"connect_status,omitempty"`
-	XXX_NoUnkeyedLiteral struct{}                   `json:"-"`
-	XXX_unrecognized     []byte                     `json:"-"`
-	XXX_sizecache        int32                      `json:"-"`
-}
-
-func (m *DeviceState) Reset()         { *m = DeviceState{} }
-func (m *DeviceState) String() string { return proto.CompactTextString(m) }
-func (*DeviceState) ProtoMessage()    {}
-func (*DeviceState) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{11}
-}
-
-func (m *DeviceState) XXX_Unmarshal(b []byte) error {
-	return xxx_messageInfo_DeviceState.Unmarshal(m, b)
-}
-func (m *DeviceState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
-	return xxx_messageInfo_DeviceState.Marshal(b, m, deterministic)
-}
-func (m *DeviceState) XXX_Merge(src proto.Message) {
-	xxx_messageInfo_DeviceState.Merge(m, src)
-}
-func (m *DeviceState) XXX_Size() int {
-	return xxx_messageInfo_DeviceState.Size(m)
-}
-func (m *DeviceState) XXX_DiscardUnknown() {
-	xxx_messageInfo_DeviceState.DiscardUnknown(m)
-}
-
-var xxx_messageInfo_DeviceState proto.InternalMessageInfo
-
-func (m *DeviceState) GetAdminState() common.AdminState_Types {
-	if m != nil {
-		return m.AdminState
-	}
-	return common.AdminState_UNKNOWN
-}
-
-func (m *DeviceState) GetOperStatus() common.OperStatus_Types {
-	if m != nil {
-		return m.OperStatus
-	}
-	return common.OperStatus_UNKNOWN
-}
-
-func (m *DeviceState) GetConnectStatus() common.ConnectStatus_Types {
-	if m != nil {
-		return m.ConnectStatus
-	}
-	return common.ConnectStatus_UNKNOWN
-}
-
-// A device state change
-type DeviceStatesChange struct {
-	Previous             *DeviceState `protobuf:"bytes,1,opt,name=previous,proto3" json:"previous,omitempty"`
-	Current              *DeviceState `protobuf:"bytes,2,opt,name=current,proto3" json:"current,omitempty"`
-	XXX_NoUnkeyedLiteral struct{}     `json:"-"`
-	XXX_unrecognized     []byte       `json:"-"`
-	XXX_sizecache        int32        `json:"-"`
-}
-
-func (m *DeviceStatesChange) Reset()         { *m = DeviceStatesChange{} }
-func (m *DeviceStatesChange) String() string { return proto.CompactTextString(m) }
-func (*DeviceStatesChange) ProtoMessage()    {}
-func (*DeviceStatesChange) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{12}
-}
-
-func (m *DeviceStatesChange) XXX_Unmarshal(b []byte) error {
-	return xxx_messageInfo_DeviceStatesChange.Unmarshal(m, b)
-}
-func (m *DeviceStatesChange) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
-	return xxx_messageInfo_DeviceStatesChange.Marshal(b, m, deterministic)
-}
-func (m *DeviceStatesChange) XXX_Merge(src proto.Message) {
-	xxx_messageInfo_DeviceStatesChange.Merge(m, src)
-}
-func (m *DeviceStatesChange) XXX_Size() int {
-	return xxx_messageInfo_DeviceStatesChange.Size(m)
-}
-func (m *DeviceStatesChange) XXX_DiscardUnknown() {
-	xxx_messageInfo_DeviceStatesChange.DiscardUnknown(m)
-}
-
-var xxx_messageInfo_DeviceStatesChange proto.InternalMessageInfo
-
-func (m *DeviceStatesChange) GetPrevious() *DeviceState {
-	if m != nil {
-		return m.Previous
-	}
-	return nil
-}
-
-func (m *DeviceStatesChange) GetCurrent() *DeviceState {
-	if m != nil {
-		return m.Current
-	}
-	return nil
-}
-
-// A device update filter
-type DeviceUpdateFilter struct {
-	// Device Id
-	DeviceId string `protobuf:"bytes,1,opt,name=device_id,json=deviceId,proto3" json:"device_id,omitempty"`
-	// Provide update starting from this timestamp, inclusive
-	FromTimestamp *timestamp.Timestamp `protobuf:"bytes,2,opt,name=from_timestamp,json=fromTimestamp,proto3" json:"from_timestamp,omitempty"`
-	// Provide update starting to this timestamp, inclusive
-	ToTimestamp *timestamp.Timestamp `protobuf:"bytes,3,opt,name=to_timestamp,json=toTimestamp,proto3" json:"to_timestamp,omitempty"`
-	// The operation that triggered the update, e.g. portCreated
-	Operation string `protobuf:"bytes,4,opt,name=operation,proto3" json:"operation,omitempty"`
-	// The ID of that operation, e.g. log correlation ID
-	OperationId string `protobuf:"bytes,5,opt,name=operation_id,json=operationId,proto3" json:"operation_id,omitempty"`
-	// Component initiating the request, e.g. openolt
-	RequestedBy string `protobuf:"bytes,6,opt,name=requested_by,json=requestedBy,proto3" json:"requested_by,omitempty"`
-	// Operation status
-	Status               *common.OperationResp `protobuf:"bytes,7,opt,name=status,proto3" json:"status,omitempty"`
-	XXX_NoUnkeyedLiteral struct{}              `json:"-"`
-	XXX_unrecognized     []byte                `json:"-"`
-	XXX_sizecache        int32                 `json:"-"`
-}
-
-func (m *DeviceUpdateFilter) Reset()         { *m = DeviceUpdateFilter{} }
-func (m *DeviceUpdateFilter) String() string { return proto.CompactTextString(m) }
-func (*DeviceUpdateFilter) ProtoMessage()    {}
-func (*DeviceUpdateFilter) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{13}
-}
-
-func (m *DeviceUpdateFilter) XXX_Unmarshal(b []byte) error {
-	return xxx_messageInfo_DeviceUpdateFilter.Unmarshal(m, b)
-}
-func (m *DeviceUpdateFilter) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
-	return xxx_messageInfo_DeviceUpdateFilter.Marshal(b, m, deterministic)
-}
-func (m *DeviceUpdateFilter) XXX_Merge(src proto.Message) {
-	xxx_messageInfo_DeviceUpdateFilter.Merge(m, src)
-}
-func (m *DeviceUpdateFilter) XXX_Size() int {
-	return xxx_messageInfo_DeviceUpdateFilter.Size(m)
-}
-func (m *DeviceUpdateFilter) XXX_DiscardUnknown() {
-	xxx_messageInfo_DeviceUpdateFilter.DiscardUnknown(m)
-}
-
-var xxx_messageInfo_DeviceUpdateFilter proto.InternalMessageInfo
-
-func (m *DeviceUpdateFilter) GetDeviceId() string {
-	if m != nil {
-		return m.DeviceId
-	}
-	return ""
-}
-
-func (m *DeviceUpdateFilter) GetFromTimestamp() *timestamp.Timestamp {
-	if m != nil {
-		return m.FromTimestamp
-	}
-	return nil
-}
-
-func (m *DeviceUpdateFilter) GetToTimestamp() *timestamp.Timestamp {
-	if m != nil {
-		return m.ToTimestamp
-	}
-	return nil
-}
-
-func (m *DeviceUpdateFilter) GetOperation() string {
-	if m != nil {
-		return m.Operation
-	}
-	return ""
-}
-
-func (m *DeviceUpdateFilter) GetOperationId() string {
-	if m != nil {
-		return m.OperationId
-	}
-	return ""
-}
-
-func (m *DeviceUpdateFilter) GetRequestedBy() string {
-	if m != nil {
-		return m.RequestedBy
-	}
-	return ""
-}
-
-func (m *DeviceUpdateFilter) GetStatus() *common.OperationResp {
-	if m != nil {
-		return m.Status
-	}
-	return nil
-}
-
-// A device update
-type DeviceUpdate struct {
-	// Device Id
-	DeviceId string `protobuf:"bytes,1,opt,name=device_id,json=deviceId,proto3" json:"device_id,omitempty"`
-	// Timestamp of the update
-	Timestamp *timestamp.Timestamp `protobuf:"bytes,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
-	// The operation that triggered the update, e.g. portCreated
-	Operation string `protobuf:"bytes,3,opt,name=operation,proto3" json:"operation,omitempty"`
-	// The ID of that operation, e.g. log correlation ID
-	OperationId string `protobuf:"bytes,4,opt,name=operation_id,json=operationId,proto3" json:"operation_id,omitempty"`
-	// Component initiating the request, e.g. openolt
-	RequestedBy string `protobuf:"bytes,5,opt,name=requested_by,json=requestedBy,proto3" json:"requested_by,omitempty"`
-	// State change, if any, as a result of that update
-	StateChange *DeviceStatesChange `protobuf:"bytes,6,opt,name=state_change,json=stateChange,proto3" json:"state_change,omitempty"`
-	// Operation status
-	Status *common.OperationResp `protobuf:"bytes,7,opt,name=status,proto3" json:"status,omitempty"`
-	// A brief description to provide more context to this update
-	Description          string   `protobuf:"bytes,8,opt,name=description,proto3" json:"description,omitempty"`
-	XXX_NoUnkeyedLiteral struct{} `json:"-"`
-	XXX_unrecognized     []byte   `json:"-"`
-	XXX_sizecache        int32    `json:"-"`
-}
-
-func (m *DeviceUpdate) Reset()         { *m = DeviceUpdate{} }
-func (m *DeviceUpdate) String() string { return proto.CompactTextString(m) }
-func (*DeviceUpdate) ProtoMessage()    {}
-func (*DeviceUpdate) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{14}
-}
-
-func (m *DeviceUpdate) XXX_Unmarshal(b []byte) error {
-	return xxx_messageInfo_DeviceUpdate.Unmarshal(m, b)
-}
-func (m *DeviceUpdate) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
-	return xxx_messageInfo_DeviceUpdate.Marshal(b, m, deterministic)
-}
-func (m *DeviceUpdate) XXX_Merge(src proto.Message) {
-	xxx_messageInfo_DeviceUpdate.Merge(m, src)
-}
-func (m *DeviceUpdate) XXX_Size() int {
-	return xxx_messageInfo_DeviceUpdate.Size(m)
-}
-func (m *DeviceUpdate) XXX_DiscardUnknown() {
-	xxx_messageInfo_DeviceUpdate.DiscardUnknown(m)
-}
-
-var xxx_messageInfo_DeviceUpdate proto.InternalMessageInfo
-
-func (m *DeviceUpdate) GetDeviceId() string {
-	if m != nil {
-		return m.DeviceId
-	}
-	return ""
-}
-
-func (m *DeviceUpdate) GetTimestamp() *timestamp.Timestamp {
-	if m != nil {
-		return m.Timestamp
-	}
-	return nil
-}
-
-func (m *DeviceUpdate) GetOperation() string {
-	if m != nil {
-		return m.Operation
-	}
-	return ""
-}
-
-func (m *DeviceUpdate) GetOperationId() string {
-	if m != nil {
-		return m.OperationId
-	}
-	return ""
-}
-
-func (m *DeviceUpdate) GetRequestedBy() string {
-	if m != nil {
-		return m.RequestedBy
-	}
-	return ""
-}
-
-func (m *DeviceUpdate) GetStateChange() *DeviceStatesChange {
-	if m != nil {
-		return m.StateChange
-	}
-	return nil
-}
-
-func (m *DeviceUpdate) GetStatus() *common.OperationResp {
-	if m != nil {
-		return m.Status
-	}
-	return nil
-}
-
-func (m *DeviceUpdate) GetDescription() string {
-	if m != nil {
-		return m.Description
-	}
-	return ""
-}
-
-type DeviceUpdates struct {
-	Items                []*DeviceUpdate `protobuf:"bytes,1,rep,name=items,proto3" json:"items,omitempty"`
-	XXX_NoUnkeyedLiteral struct{}        `json:"-"`
-	XXX_unrecognized     []byte          `json:"-"`
-	XXX_sizecache        int32           `json:"-"`
-}
-
-func (m *DeviceUpdates) Reset()         { *m = DeviceUpdates{} }
-func (m *DeviceUpdates) String() string { return proto.CompactTextString(m) }
-func (*DeviceUpdates) ProtoMessage()    {}
-func (*DeviceUpdates) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{15}
-}
-
-func (m *DeviceUpdates) XXX_Unmarshal(b []byte) error {
-	return xxx_messageInfo_DeviceUpdates.Unmarshal(m, b)
-}
-func (m *DeviceUpdates) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
-	return xxx_messageInfo_DeviceUpdates.Marshal(b, m, deterministic)
-}
-func (m *DeviceUpdates) XXX_Merge(src proto.Message) {
-	xxx_messageInfo_DeviceUpdates.Merge(m, src)
-}
-func (m *DeviceUpdates) XXX_Size() int {
-	return xxx_messageInfo_DeviceUpdates.Size(m)
-}
-func (m *DeviceUpdates) XXX_DiscardUnknown() {
-	xxx_messageInfo_DeviceUpdates.DiscardUnknown(m)
-}
-
-var xxx_messageInfo_DeviceUpdates proto.InternalMessageInfo
-
-func (m *DeviceUpdates) GetItems() []*DeviceUpdate {
-	if m != nil {
-		return m.Items
-	}
-	return nil
-}
-
 // A Physical Device instance
 type Device struct {
 	// Voltha's device identifier
@@ -1521,6 +1178,7 @@
 	ProxyAddress  *Device_ProxyAddress       `protobuf:"bytes,19,opt,name=proxy_address,json=proxyAddress,proto3" json:"proxy_address,omitempty"`
 	AdminState    common.AdminState_Types    `protobuf:"varint,16,opt,name=admin_state,json=adminState,proto3,enum=common.AdminState_Types" json:"admin_state,omitempty"`
 	OperStatus    common.OperStatus_Types    `protobuf:"varint,17,opt,name=oper_status,json=operStatus,proto3,enum=common.OperStatus_Types" json:"oper_status,omitempty"`
+	Reason        string                     `protobuf:"bytes,22,opt,name=reason,proto3" json:"reason,omitempty"`
 	ConnectStatus common.ConnectStatus_Types `protobuf:"varint,18,opt,name=connect_status,json=connectStatus,proto3,enum=common.ConnectStatus_Types" json:"connect_status,omitempty"`
 	// Device type specific attributes
 	Custom *any.Any `protobuf:"bytes,64,opt,name=custom,proto3" json:"custom,omitempty"`
@@ -1537,7 +1195,7 @@
 func (m *Device) String() string { return proto.CompactTextString(m) }
 func (*Device) ProtoMessage()    {}
 func (*Device) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{16}
+	return fileDescriptor_200940f73d155856, []int{11}
 }
 
 func (m *Device) XXX_Unmarshal(b []byte) error {
@@ -1741,6 +1399,13 @@
 	return common.OperStatus_UNKNOWN
 }
 
+func (m *Device) GetReason() string {
+	if m != nil {
+		return m.Reason
+	}
+	return ""
+}
+
 func (m *Device) GetConnectStatus() common.ConnectStatus_Types {
 	if m != nil {
 		return m.ConnectStatus
@@ -1795,7 +1460,7 @@
 func (m *Device_ProxyAddress) String() string { return proto.CompactTextString(m) }
 func (*Device_ProxyAddress) ProtoMessage()    {}
 func (*Device_ProxyAddress) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{16, 0}
+	return fileDescriptor_200940f73d155856, []int{11, 0}
 }
 
 func (m *Device_ProxyAddress) XXX_Unmarshal(b []byte) error {
@@ -1876,7 +1541,7 @@
 func (m *Devices) String() string { return proto.CompactTextString(m) }
 func (*Devices) ProtoMessage()    {}
 func (*Devices) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{17}
+	return fileDescriptor_200940f73d155856, []int{12}
 }
 
 func (m *Devices) XXX_Unmarshal(b []byte) error {
@@ -1925,7 +1590,7 @@
 func (m *SimulateAlarmRequest) String() string { return proto.CompactTextString(m) }
 func (*SimulateAlarmRequest) ProtoMessage()    {}
 func (*SimulateAlarmRequest) Descriptor() ([]byte, []int) {
-	return fileDescriptor_200940f73d155856, []int{18}
+	return fileDescriptor_200940f73d155856, []int{13}
 }
 
 func (m *SimulateAlarmRequest) XXX_Unmarshal(b []byte) error {
@@ -2035,11 +1700,6 @@
 	proto.RegisterType((*Port)(nil), "voltha.Port")
 	proto.RegisterType((*Port_PeerPort)(nil), "voltha.Port.PeerPort")
 	proto.RegisterType((*Ports)(nil), "voltha.Ports")
-	proto.RegisterType((*DeviceState)(nil), "voltha.DeviceState")
-	proto.RegisterType((*DeviceStatesChange)(nil), "voltha.DeviceStatesChange")
-	proto.RegisterType((*DeviceUpdateFilter)(nil), "voltha.DeviceUpdateFilter")
-	proto.RegisterType((*DeviceUpdate)(nil), "voltha.DeviceUpdate")
-	proto.RegisterType((*DeviceUpdates)(nil), "voltha.DeviceUpdates")
 	proto.RegisterType((*Device)(nil), "voltha.Device")
 	proto.RegisterType((*Device_ProxyAddress)(nil), "voltha.Device.ProxyAddress")
 	proto.RegisterType((*Devices)(nil), "voltha.Devices")
@@ -2049,168 +1709,152 @@
 func init() { proto.RegisterFile("voltha_protos/device.proto", fileDescriptor_200940f73d155856) }
 
 var fileDescriptor_200940f73d155856 = []byte{
-	// 2606 bytes of a gzipped FileDescriptorProto
-	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x9c, 0x58, 0xcd, 0x73, 0xdb, 0xc6,
-	0x15, 0x37, 0x29, 0xf1, 0xeb, 0xf1, 0x43, 0xf0, 0x5a, 0x4e, 0x60, 0x29, 0x1a, 0xbb, 0x74, 0x3a,
-	0x55, 0x9c, 0x5a, 0x72, 0x9d, 0x4c, 0x92, 0x4e, 0x27, 0x33, 0xa6, 0x48, 0xc8, 0xe6, 0x54, 0xa5,
-	0xd4, 0x25, 0xa5, 0xb4, 0xbd, 0x60, 0x20, 0x62, 0x29, 0x61, 0x0c, 0x60, 0xe1, 0x5d, 0x90, 0x92,
-	0x72, 0xeb, 0x64, 0xda, 0x53, 0x6f, 0xfd, 0x27, 0xfa, 0x1f, 0xe4, 0xd8, 0x9e, 0xda, 0x53, 0xa6,
-	0xe7, 0x5e, 0xdb, 0x4b, 0xff, 0x82, 0x5c, 0x7a, 0xe9, 0xec, 0x17, 0x01, 0x48, 0x89, 0x5d, 0xf7,
-	0x22, 0x71, 0x7f, 0xef, 0x03, 0xbb, 0xbf, 0x7d, 0xfb, 0xde, 0xdb, 0x85, 0x8d, 0x05, 0x0d, 0xd3,
-	0x73, 0xcf, 0x4d, 0x18, 0x4d, 0x29, 0xdf, 0xf5, 0xc9, 0x22, 0x98, 0x92, 0x1d, 0x39, 0x42, 0x55,
-	0x25, 0xdb, 0xb8, 0x77, 0x46, 0xe9, 0x59, 0x48, 0x76, 0x25, 0x7a, 0x3a, 0x9f, 0xed, 0x7a, 0xf1,
-	0x95, 0x52, 0xd9, 0xb8, 0x7f, 0x5d, 0x94, 0x06, 0x11, 0xe1, 0xa9, 0x17, 0x25, 0x5a, 0xe1, 0x9a,
-	0xff, 0x29, 0x8d, 0x22, 0x1a, 0x6b, 0x99, 0x5d, 0x94, 0x45, 0x24, 0xf5, 0x8c, 0xdb, 0xa2, 0x84,
-	0x26, 0x24, 0x9e, 0x85, 0xf4, 0xc2, 0xfd, 0xc9, 0x47, 0x4a, 0xa1, 0xfb, 0xe7, 0x32, 0xc0, 0x40,
-	0xce, 0x75, 0x72, 0x95, 0x10, 0xd4, 0x81, 0x72, 0xe0, 0xdb, 0xa5, 0x07, 0xa5, 0xed, 0x06, 0x2e,
-	0x07, 0x3e, 0xda, 0x84, 0xc6, 0x82, 0xc4, 0x3e, 0x65, 0x6e, 0xe0, 0xdb, 0x15, 0x09, 0xd7, 0x15,
-	0x30, 0xf4, 0xd1, 0x16, 0xc0, 0x52, 0xc8, 0xed, 0xea, 0x83, 0x95, 0xed, 0x06, 0x6e, 0x18, 0x29,
-	0x47, 0x36, 0xd4, 0x3c, 0xdf, 0x4b, 0x52, 0xc2, 0xec, 0xb2, 0xb4, 0x34, 0x43, 0xf4, 0x29, 0xd8,
-	0xde, 0x74, 0x4a, 0x92, 0x94, 0xbb, 0xa7, 0xf3, 0xf0, 0xa5, 0x2b, 0xa7, 0x34, 0x4f, 0x7c, 0x2f,
-	0x25, 0xf6, 0xca, 0x83, 0xd2, 0x76, 0x1d, 0xdf, 0xd5, 0xf2, 0xbd, 0x79, 0xf8, 0x72, 0x3f, 0xa4,
-	0x17, 0xc7, 0x52, 0x88, 0x06, 0x70, 0xdf, 0x18, 0x7a, 0xbe, 0xef, 0x32, 0x12, 0xd1, 0x05, 0xc9,
-	0x9b, 0x73, 0x7b, 0x55, 0xda, 0x6f, 0x6a, 0xb5, 0x9e, 0xef, 0x63, 0xa9, 0x94, 0x39, 0xe1, 0xe8,
-	0x00, 0x1e, 0x1a, 0x2f, 0x7e, 0xc0, 0xc8, 0x34, 0x75, 0x43, 0x7a, 0x16, 0x4c, 0xbd, 0x50, 0x7a,
-	0xe2, 0x66, 0x26, 0x35, 0xe9, 0xc9, 0x7c, 0x70, 0x20, 0x35, 0x0f, 0x94, 0xa2, 0xf0, 0xc6, 0x95,
-	0xbb, 0xee, 0xa7, 0xd0, 0xcc, 0x08, 0xe4, 0x68, 0x1b, 0x2a, 0x41, 0x4a, 0x22, 0x6e, 0x97, 0x1e,
-	0xac, 0x6c, 0x37, 0x9f, 0xa2, 0x1d, 0xb5, 0x03, 0x3b, 0x99, 0x0e, 0x56, 0x0a, 0xdd, 0xbf, 0x94,
-	0xa0, 0x7e, 0x14, 0xf5, 0x69, 0x3c, 0x0b, 0xce, 0x10, 0x82, 0xd5, 0xd8, 0x8b, 0x88, 0xa6, 0x5e,
-	0xfe, 0x46, 0x1f, 0xc2, 0x6a, 0x7a, 0x95, 0x10, 0xc9, 0x5e, 0xe7, 0xe9, 0xbb, 0xc6, 0x93, 0xb1,
-	0xd9, 0x39, 0x8a, 0xa4, 0x3b, 0xa9, 0x24, 0xd8, 0x26, 0xb1, 0x77, 0x1a, 0x12, 0x5f, 0x53, 0x68,
-	0x86, 0xe8, 0x3e, 0x34, 0xb9, 0x17, 0x25, 0x21, 0x71, 0x67, 0x8c, 0xbc, 0x92, 0x04, 0xb5, 0x31,
-	0x28, 0x68, 0x9f, 0x91, 0x57, 0xdd, 0xcf, 0xa0, 0xaa, 0x5c, 0xa1, 0x26, 0xd4, 0xfa, 0x87, 0xc7,
-	0xa3, 0x89, 0x83, 0xad, 0x5b, 0xa8, 0x01, 0x95, 0xe7, 0xbd, 0xe3, 0xe7, 0x8e, 0x55, 0x12, 0x3f,
-	0xc7, 0x93, 0xde, 0xc4, 0xb1, 0xca, 0x4a, 0x65, 0x34, 0x71, 0x7e, 0x35, 0xb1, 0x56, 0xba, 0x7f,
-	0x2c, 0x41, 0xfb, 0x28, 0x7a, 0xce, 0xe8, 0x3c, 0xd1, 0xeb, 0xd8, 0x02, 0x38, 0x13, 0x43, 0x37,
-	0xb7, 0x9a, 0x86, 0x44, 0x46, 0x62, 0x49, 0x4b, 0xb1, 0x9c, 0x4a, 0x59, 0x4e, 0x45, 0x89, 0xc5,
-	0x4c, 0x5e, 0xb3, 0x88, 0x47, 0x50, 0x8b, 0x48, 0xca, 0x82, 0xa9, 0xd8, 0x61, 0x41, 0xac, 0x75,
-	0x9d, 0x0e, 0x6c, 0x14, 0xba, 0xbf, 0x2d, 0x43, 0xc3, 0xa0, 0xfc, 0x46, 0x48, 0xff, 0x00, 0x5a,
-	0x3e, 0x99, 0x79, 0xf3, 0x30, 0xcd, 0x4f, 0xa2, 0xa9, 0x31, 0x39, 0x8d, 0xfb, 0x50, 0x93, 0x73,
-	0x32, 0xd3, 0xd8, 0xab, 0xfc, 0xfb, 0xdb, 0x6f, 0xb6, 0x4a, 0xd8, 0xa0, 0xe8, 0x11, 0xb4, 0x85,
-	0xad, 0x4b, 0x17, 0x84, 0xb1, 0xc0, 0x27, 0x2a, 0xea, 0x8c, 0x5a, 0x4b, 0xc8, 0x0e, 0xb5, 0x08,
-	0x3d, 0x86, 0xaa, 0x34, 0xe3, 0x76, 0x45, 0x4e, 0xfc, 0x6e, 0x36, 0xf1, 0x1c, 0x71, 0x58, 0x2b,
-	0xe5, 0x17, 0x5a, 0x7d, 0xc3, 0x42, 0xd1, 0x3d, 0xa8, 0x47, 0xde, 0xa5, 0xcb, 0x5f, 0x92, 0x0b,
-	0x19, 0xad, 0x6d, 0x5c, 0x8b, 0xbc, 0xcb, 0xf1, 0x4b, 0x72, 0xd1, 0xfd, 0x7b, 0x09, 0x2a, 0xc3,
-	0xc8, 0x3b, 0x23, 0xdf, 0x19, 0x59, 0x36, 0xd4, 0x16, 0x84, 0xf1, 0x80, 0xc6, 0xe6, 0x68, 0xea,
-	0xa1, 0xd0, 0x3e, 0xf7, 0xf8, 0xb9, 0x5c, 0x77, 0x03, 0xcb, 0xdf, 0xe8, 0x03, 0xb0, 0x82, 0x98,
-	0xa7, 0x5e, 0x18, 0xba, 0x22, 0xe2, 0x45, 0x66, 0x92, 0x0b, 0x6e, 0xe0, 0x35, 0x8d, 0x0f, 0x34,
-	0x2c, 0xf2, 0x45, 0xc0, 0x5d, 0x6f, 0x9a, 0x06, 0x0b, 0x22, 0xf3, 0x45, 0x1d, 0xd7, 0x03, 0xde,
-	0x93, 0x63, 0xc1, 0x7c, 0xc0, 0x5d, 0x91, 0xb9, 0x82, 0x34, 0x25, 0xbe, 0x5d, 0x95, 0xf2, 0x66,
-	0xc0, 0xfb, 0x06, 0x12, 0x2b, 0x0a, 0xb8, 0xbb, 0xf0, 0xc2, 0xc0, 0xd7, 0xe7, 0xaf, 0x16, 0xf0,
-	0x13, 0x31, 0xec, 0x3e, 0x86, 0xaa, 0x5c, 0x10, 0x47, 0x0f, 0xa1, 0x12, 0x88, 0x5f, 0xfa, 0x88,
-	0xb5, 0x0d, 0x41, 0x52, 0x8c, 0x95, 0xac, 0xfb, 0xaf, 0x1a, 0xb4, 0x25, 0x30, 0xa0, 0x17, 0x71,
-	0x48, 0x3d, 0xff, 0x46, 0x20, 0x18, 0x62, 0xca, 0x39, 0x62, 0x2c, 0x58, 0x99, 0xb3, 0x50, 0xaf,
-	0x5e, 0xfc, 0x14, 0xc8, 0x94, 0x4d, 0xf5, 0xa9, 0x11, 0x3f, 0xd1, 0x21, 0x74, 0x7c, 0xed, 0xd3,
-	0xe5, 0xa9, 0xc8, 0x14, 0x15, 0x79, 0x40, 0xb7, 0x0b, 0xf3, 0x30, 0x9f, 0x2d, 0x8e, 0xc6, 0x42,
-	0x1f, 0xb7, 0xfd, 0xfc, 0x10, 0x3d, 0x84, 0xb6, 0x9c, 0xb3, 0x6b, 0xf6, 0xa4, 0x2a, 0x3f, 0xdf,
-	0x92, 0xe0, 0x89, 0xde, 0x98, 0x0f, 0xc0, 0x32, 0x56, 0xc4, 0x77, 0x4f, 0xaf, 0x44, 0xae, 0x53,
-	0x7b, 0xbe, 0x96, 0xe1, 0x7b, 0x02, 0x46, 0x2f, 0xa0, 0xca, 0x88, 0xc7, 0x69, 0x6c, 0xd7, 0xe5,
-	0xc4, 0x9e, 0xfc, 0x0f, 0x13, 0xdb, 0xf7, 0x82, 0x70, 0xce, 0x08, 0x96, 0x76, 0x58, 0xdb, 0xa3,
-	0x1f, 0xc1, 0x9a, 0xe7, 0xfb, 0x41, 0x1a, 0xd0, 0xd8, 0x0b, 0xdd, 0x20, 0x9e, 0x51, 0xbb, 0x21,
-	0xe7, 0xd6, 0xc9, 0xe0, 0x61, 0x3c, 0xa3, 0x2a, 0xc7, 0x2c, 0x88, 0x3b, 0x95, 0x11, 0x6a, 0x83,
-	0xdc, 0x3a, 0x10, 0x90, 0xce, 0x0b, 0x9b, 0xd0, 0x08, 0xa9, 0x48, 0xb1, 0x7e, 0xc0, 0xec, 0xa6,
-	0x2a, 0x24, 0x12, 0x18, 0x04, 0x0c, 0x0d, 0xa1, 0xa9, 0x08, 0x50, 0x74, 0xb6, 0xde, 0x48, 0xa7,
-	0x0c, 0x28, 0x2f, 0x25, 0x8a, 0x4e, 0x90, 0xc6, 0x8a, 0xcb, 0x4d, 0x68, 0xcc, 0x82, 0x90, 0xb8,
-	0x3c, 0xf8, 0x92, 0xd8, 0x6d, 0xc9, 0x4f, 0x5d, 0x00, 0xe3, 0xe0, 0x4b, 0xd2, 0xfd, 0xba, 0x04,
-	0xe8, 0xe6, 0x76, 0xa0, 0x75, 0xb0, 0x06, 0x87, 0x5f, 0x8c, 0x0e, 0x0e, 0x7b, 0x03, 0xf7, 0x78,
-	0xf4, 0xf3, 0xd1, 0xe1, 0x17, 0x23, 0xeb, 0x16, 0x7a, 0x07, 0xd0, 0x12, 0x1d, 0x1f, 0xf7, 0xfb,
-	0x8e, 0x33, 0x70, 0x06, 0x56, 0xa9, 0x80, 0x63, 0xe7, 0x97, 0xc7, 0xce, 0x78, 0xe2, 0x0c, 0xac,
-	0x72, 0xc1, 0xcb, 0x78, 0xd2, 0xc3, 0x02, 0x5d, 0x41, 0x77, 0x60, 0x6d, 0x89, 0xee, 0xf7, 0x86,
-	0x07, 0xce, 0xc0, 0x5a, 0x45, 0x36, 0xac, 0xe7, 0x3e, 0x38, 0x3e, 0x3e, 0x3a, 0x3a, 0x94, 0xea,
-	0x95, 0x82, 0xf3, 0x7e, 0x6f, 0xd4, 0x77, 0x0e, 0x84, 0x45, 0xb5, 0xfb, 0xfb, 0x12, 0x6c, 0x7c,
-	0xff, 0x7e, 0xa1, 0x16, 0xd4, 0x47, 0x87, 0xae, 0x83, 0xf1, 0xa1, 0x48, 0xdc, 0x6b, 0xd0, 0x1c,
-	0x8e, 0x4e, 0x7a, 0x07, 0xc3, 0x81, 0x7b, 0x8c, 0x0f, 0xac, 0x92, 0x00, 0x06, 0xce, 0xc9, 0xb0,
-	0xef, 0xb8, 0x7b, 0xc7, 0xe3, 0x5f, 0x5b, 0x65, 0xf1, 0x99, 0xe1, 0x68, 0x7c, 0xbc, 0xbf, 0x3f,
-	0xec, 0x0f, 0x9d, 0xd1, 0xc4, 0x1d, 0x1f, 0xf5, 0xfa, 0x8e, 0xb5, 0x82, 0x6e, 0x43, 0x5b, 0x13,
-	0xa0, 0x9d, 0xad, 0xa2, 0x36, 0x34, 0xb2, 0x89, 0x54, 0xba, 0x7f, 0x30, 0x14, 0x16, 0xb6, 0x40,
-	0x18, 0x0e, 0x7f, 0xd1, 0x7b, 0xee, 0xe4, 0xf8, 0x43, 0xd0, 0x51, 0xd0, 0x70, 0xd4, 0xeb, 0x4f,
-	0x86, 0x27, 0xa2, 0x8e, 0xac, 0x83, 0xa5, 0x30, 0x89, 0xf4, 0x26, 0xc3, 0xd1, 0x73, 0xab, 0x8c,
-	0x2c, 0x68, 0xe5, 0x50, 0x47, 0xb1, 0xa6, 0x10, 0xec, 0x9c, 0x38, 0x58, 0xaa, 0xad, 0x66, 0x0e,
-	0x15, 0x28, 0xa7, 0xf3, 0x39, 0x74, 0x0a, 0xb4, 0x70, 0xf4, 0xa1, 0xa9, 0xbf, 0xe5, 0x62, 0xb6,
-	0x2d, 0xa8, 0x99, 0x12, 0xfc, 0x75, 0x05, 0x56, 0x8f, 0x28, 0x4b, 0xd1, 0xbb, 0x50, 0x4b, 0x28,
-	0x4b, 0xdd, 0x98, 0xca, 0x04, 0xd1, 0xc6, 0x55, 0x31, 0x1c, 0x51, 0xb4, 0x0e, 0x95, 0xd0, 0x3b,
-	0x25, 0xa1, 0xce, 0x12, 0x6a, 0x80, 0x3e, 0xd0, 0x95, 0x79, 0x45, 0x46, 0x6a, 0x96, 0xd1, 0x29,
-	0x4b, 0xe5, 0x9f, 0x5c, 0x5d, 0xfe, 0x29, 0x34, 0x3d, 0x3f, 0x0a, 0xe2, 0x42, 0xaa, 0xb0, 0x77,
-	0x74, 0xff, 0xd6, 0x13, 0x22, 0x49, 0xe1, 0x8e, 0x6c, 0x1f, 0x30, 0x78, 0x4b, 0x44, 0x98, 0xd2,
-	0x84, 0x30, 0x69, 0x39, 0xe7, 0x32, 0x2b, 0xe4, 0x4c, 0x0f, 0x13, 0xc2, 0xc6, 0x52, 0x62, 0x4c,
-	0xe9, 0x12, 0x11, 0xc7, 0x40, 0x75, 0xa0, 0xae, 0x4e, 0xa4, 0x0d, 0x5c, 0x57, 0xc0, 0xd0, 0x17,
-	0x14, 0x25, 0x84, 0x30, 0x6e, 0xd7, 0xaf, 0x15, 0x24, 0x39, 0x7d, 0x42, 0x98, 0xf8, 0x81, 0x95,
-	0x8e, 0xa8, 0xd8, 0xec, 0xd2, 0x4d, 0xbc, 0xe9, 0x4b, 0x92, 0x72, 0x79, 0xfa, 0xab, 0xb8, 0xc1,
-	0x2e, 0x8f, 0x14, 0x20, 0x12, 0x36, 0xbb, 0xd4, 0xe9, 0x08, 0xa4, 0xb0, 0xc6, 0x2e, 0x55, 0x1a,
-	0xda, 0x84, 0x06, 0xbb, 0x74, 0x09, 0x63, 0x94, 0x71, 0x79, 0xe4, 0xab, 0xb8, 0xce, 0x2e, 0x1d,
-	0x39, 0x16, 0x6e, 0xd3, 0xcc, 0x6d, 0x4b, 0xb9, 0x4d, 0xf3, 0x6e, 0x53, 0xe3, 0xb6, 0xad, 0xdc,
-	0xa6, 0x99, 0xdb, 0x74, 0xe9, 0xb6, 0xa3, 0xdc, 0xa6, 0xc6, 0xed, 0x13, 0xa8, 0xd3, 0x59, 0xe2,
-	0x8a, 0xcd, 0xb3, 0xd7, 0x1e, 0x94, 0xe4, 0xea, 0xf2, 0x4d, 0xaf, 0x11, 0xe2, 0x1a, 0x9d, 0x25,
-	0x62, 0x99, 0x1b, 0xcf, 0xa0, 0x6e, 0x96, 0x5c, 0x64, 0xad, 0x74, 0x8d, 0xb5, 0x5c, 0x88, 0x94,
-	0xf3, 0x21, 0xd2, 0xe5, 0x50, 0x37, 0x7b, 0x2e, 0xba, 0xa3, 0xec, 0x04, 0x58, 0xd0, 0x72, 0x26,
-	0x2f, 0x1c, 0x3c, 0x72, 0x26, 0xee, 0x68, 0x34, 0xb4, 0x4a, 0x05, 0xe4, 0x78, 0x34, 0x54, 0xed,
-	0xd4, 0xd1, 0xe1, 0xc8, 0x3d, 0x3c, 0x98, 0x58, 0x2b, 0xcb, 0xc1, 0xe8, 0x58, 0x1d, 0xbc, 0x13,
-	0x47, 0x28, 0x0a, 0x59, 0x25, 0x37, 0x1c, 0x1d, 0x5b, 0xd5, 0xee, 0x87, 0x50, 0x11, 0x1f, 0xe5,
-	0xa8, 0x5b, 0xec, 0x37, 0x5b, 0xf9, 0xcd, 0x34, 0x61, 0xfe, 0xb7, 0x92, 0xe9, 0x51, 0x97, 0x81,
-	0x95, 0x8f, 0xc9, 0xd2, 0xff, 0x1f, 0x93, 0xe5, 0xb7, 0x88, 0xc9, 0x3d, 0xe8, 0x4c, 0x69, 0x1c,
-	0x8b, 0x7e, 0x5b, 0x5b, 0xab, 0xe3, 0xb3, 0x69, 0xac, 0xfb, 0x4a, 0x5a, 0x70, 0xd0, 0x9e, 0xe6,
-	0xc1, 0x6e, 0x0a, 0x28, 0xb7, 0x10, 0xde, 0x3f, 0xf7, 0xe2, 0x33, 0x82, 0x76, 0xa1, 0x9e, 0x30,
-	0xb2, 0x08, 0xe8, 0x9c, 0xcb, 0xc5, 0x34, 0x9f, 0xde, 0x29, 0xb6, 0xdd, 0xaa, 0x4e, 0x2c, 0x95,
-	0xd0, 0x63, 0xa8, 0x4d, 0xe7, 0x8c, 0x91, 0x38, 0x95, 0x2b, 0xf8, 0x1e, 0x7d, 0xa3, 0xd3, 0xfd,
-	0x6b, 0xd9, 0x7c, 0x56, 0xf5, 0xfc, 0xfb, 0x41, 0x28, 0xae, 0x31, 0xaf, 0x0d, 0x97, 0x1e, 0x74,
-	0x66, 0x8c, 0x46, 0xee, 0xf2, 0x1e, 0xa7, 0xbf, 0xb4, 0xb1, 0xa3, 0x6e, 0x7a, 0x3b, 0xe6, 0xa6,
-	0xb7, 0x33, 0x31, 0x1a, 0xb8, 0x2d, 0x2c, 0x96, 0x43, 0xf4, 0x39, 0xb4, 0x52, 0x9a, 0x73, 0xb0,
-	0xf2, 0x46, 0x07, 0xcd, 0x94, 0x66, 0xe6, 0xef, 0x41, 0x43, 0xb0, 0xef, 0x89, 0x32, 0xad, 0xfb,
-	0xb5, 0x0c, 0x10, 0xcd, 0xd8, 0x72, 0x90, 0x5d, 0xee, 0x9a, 0x4b, 0x6c, 0x28, 0x3b, 0x65, 0x46,
-	0x5e, 0xcd, 0x09, 0x4f, 0x65, 0xc7, 0xa1, 0xdb, 0x92, 0xe6, 0x12, 0xdb, 0xbb, 0x12, 0xcd, 0xad,
-	0xde, 0xcb, 0x9a, 0x3e, 0x6d, 0xb9, 0x48, 0x90, 0x7e, 0x30, 0xe1, 0x09, 0xd6, 0x4a, 0xdd, 0x7f,
-	0x94, 0xa1, 0x95, 0x27, 0xf2, 0xf5, 0x14, 0x7e, 0x06, 0x8d, 0xb7, 0x61, 0x2f, 0x53, 0x2e, 0x2e,
-	0x7d, 0xe5, 0x4d, 0x4b, 0x5f, 0x7d, 0xf3, 0xd2, 0x2b, 0x37, 0x97, 0xfe, 0x39, 0xb4, 0xe4, 0xf1,
-	0x71, 0xa7, 0x32, 0x08, 0x25, 0x3b, 0x62, 0x82, 0x37, 0x03, 0x49, 0x87, 0x29, 0x6e, 0x4a, 0x7d,
-	0x1d, 0xb3, 0x6f, 0xc7, 0x1c, 0x7a, 0x00, 0x4d, 0x9f, 0xf0, 0x29, 0x0b, 0x12, 0xb9, 0xa6, 0xba,
-	0x9a, 0x4f, 0x0e, 0xea, 0xfe, 0x0c, 0xda, 0x79, 0x6a, 0xc5, 0x4d, 0xa2, 0x90, 0x19, 0xd6, 0x8b,
-	0x33, 0x53, 0x5a, 0x26, 0x43, 0xfc, 0x07, 0xa0, 0xaa, 0x70, 0x74, 0x37, 0x6b, 0x93, 0xcd, 0x85,
-	0x46, 0x74, 0xcb, 0xf7, 0x72, 0x97, 0xd1, 0xa5, 0x40, 0x95, 0xb8, 0x7b, 0xb0, 0xca, 0x28, 0x4d,
-	0x8b, 0x77, 0x25, 0x09, 0xa1, 0x2e, 0x34, 0x12, 0x4f, 0x9c, 0xa1, 0x25, 0xcf, 0x46, 0x5e, 0x57,
-	0xb8, 0x2c, 0x47, 0x1d, 0xad, 0x63, 0xf2, 0xeb, 0xba, 0xc8, 0xaf, 0xcb, 0xdb, 0x94, 0x12, 0x1e,
-	0xa9, 0x7a, 0xbc, 0x05, 0x55, 0xf5, 0xc2, 0xa0, 0xb6, 0xc4, 0x28, 0x69, 0x10, 0x6d, 0x42, 0x25,
-	0xa2, 0x3e, 0x09, 0x55, 0xac, 0x1a, 0xa9, 0xc2, 0xd0, 0x13, 0xb0, 0xce, 0x3d, 0xe6, 0x5f, 0x78,
-	0x2c, 0x6b, 0xb5, 0x6b, 0x79, 0xbd, 0x35, 0x23, 0x36, 0x4d, 0xf7, 0x13, 0xb0, 0x66, 0x01, 0x8b,
-	0x0a, 0x16, 0xf5, 0x82, 0x85, 0x11, 0x1b, 0x8b, 0xc7, 0x50, 0x95, 0xdd, 0xa8, 0x2a, 0x95, 0xcd,
-	0xa7, 0x9d, 0x42, 0xff, 0xc1, 0x97, 0xf3, 0x55, 0x4a, 0xe2, 0x22, 0xc9, 0x09, 0x0b, 0xbc, 0xd0,
-	0x8d, 0xe7, 0xd1, 0x29, 0x61, 0xb2, 0x86, 0x2e, 0xbd, 0xb7, 0x94, 0x6c, 0x24, 0x45, 0x82, 0xcb,
-	0xec, 0x2d, 0xc6, 0x2e, 0x70, 0xb9, 0x7c, 0x92, 0xb9, 0x9f, 0xbd, 0xb9, 0x34, 0xf3, 0x1a, 0xcb,
-	0xa7, 0x17, 0x04, 0xab, 0x8b, 0xd0, 0x8b, 0x65, 0xc5, 0x6d, 0x63, 0xf9, 0x5b, 0x34, 0xef, 0x91,
-	0x37, 0x75, 0x3d, 0xdf, 0x67, 0x84, 0xab, 0x7a, 0xdb, 0xc0, 0x10, 0x79, 0xd3, 0x9e, 0x42, 0xd0,
-	0x43, 0x68, 0x05, 0xc9, 0xe2, 0xe3, 0xa5, 0x86, 0xa8, 0xba, 0x8d, 0x17, 0xb7, 0x70, 0x53, 0xa0,
-	0x45, 0xa5, 0x4f, 0x96, 0x4a, 0x6b, 0x39, 0xa5, 0x4f, 0x8c, 0xd2, 0xfb, 0xd0, 0x3e, 0xa7, 0x3c,
-	0x75, 0xbd, 0xd8, 0x57, 0x45, 0xfa, 0xae, 0xd1, 0x12, 0x70, 0x2f, 0xf6, 0x65, 0x1d, 0xde, 0x02,
-	0x20, 0x97, 0x29, 0xf3, 0x5c, 0x8f, 0x9d, 0x71, 0xfb, 0x5d, 0x75, 0x7e, 0x25, 0xd2, 0x63, 0x67,
-	0x1c, 0x3d, 0x83, 0x76, 0xc2, 0xe8, 0xe5, 0xd5, 0xf2, 0x53, 0x77, 0x24, 0xd5, 0x9b, 0xc5, 0x00,
-	0xdf, 0x39, 0x12, 0x3a, 0xfa, 0xc3, 0xb8, 0x95, 0xe4, 0x46, 0xd7, 0x0b, 0xa0, 0xf5, 0x16, 0x05,
-	0xf0, 0x59, 0xb1, 0x00, 0xde, 0x7e, 0x7d, 0x01, 0x34, 0xfc, 0xe7, 0xeb, 0xe0, 0xf0, 0x46, 0x1d,
-	0x44, 0x6f, 0xac, 0x83, 0xc6, 0x4f, 0xb1, 0x1c, 0xa2, 0x1f, 0x43, 0x75, 0x3a, 0xe7, 0x29, 0x8d,
-	0xec, 0x67, 0x92, 0x82, 0xf5, 0x1b, 0xe9, 0xb1, 0x17, 0x5f, 0x61, 0xad, 0x83, 0x3e, 0x03, 0x48,
-	0x22, 0x7d, 0x45, 0xe3, 0xf6, 0x57, 0xaa, 0x52, 0xde, 0xbe, 0xfe, 0xbc, 0xc0, 0xf7, 0x2a, 0xff,
-	0xfc, 0xf6, 0x9b, 0xad, 0x5b, 0xb8, 0x91, 0x2c, 0xdf, 0x50, 0x0e, 0x60, 0x4d, 0x5d, 0xd0, 0xcc,
-	0x55, 0x93, 0xdb, 0xbf, 0x2b, 0xbd, 0xa6, 0xbf, 0xde, 0x6b, 0x0a, 0x17, 0x55, 0x75, 0xc1, 0xc6,
-	0x9d, 0xa0, 0xd0, 0xa2, 0x6f, 0x7c, 0x55, 0x86, 0x56, 0x7e, 0x73, 0x5e, 0x5f, 0x05, 0xee, 0x8b,
-	0xcc, 0x27, 0x85, 0x59, 0xfe, 0xc1, 0xe0, 0x67, 0x6f, 0x96, 0x5b, 0x00, 0x22, 0x05, 0xc7, 0x24,
-	0x14, 0xe6, 0x2b, 0xea, 0x4d, 0x49, 0x23, 0x43, 0x1f, 0x6d, 0x83, 0x65, 0xc4, 0xea, 0xe9, 0x49,
-	0x67, 0xa2, 0x36, 0xee, 0x68, 0x5c, 0x3e, 0xc3, 0x0c, 0x7d, 0xb4, 0x0b, 0x77, 0x8c, 0x66, 0x4a,
-	0x58, 0x14, 0xc4, 0xaa, 0x7e, 0xa8, 0xdc, 0x8f, 0xb4, 0x68, 0x92, 0x49, 0xd0, 0x5d, 0xa8, 0xd2,
-	0x78, 0x2e, 0x1c, 0x56, 0xa5, 0xc3, 0x0a, 0x8d, 0xe7, 0x43, 0x1f, 0xbd, 0x0f, 0x1d, 0x01, 0x73,
-	0xc2, 0xb9, 0xae, 0x30, 0xea, 0xa2, 0xde, 0xa2, 0xf1, 0x7c, 0xac, 0xc0, 0xa1, 0xbf, 0xd7, 0x10,
-	0x47, 0x55, 0xae, 0xbf, 0xbb, 0x0b, 0x35, 0x15, 0xb3, 0xe2, 0x80, 0x14, 0x92, 0x76, 0xa7, 0x18,
-	0xd3, 0x26, 0x5d, 0xff, 0x69, 0x05, 0xd6, 0xc7, 0x41, 0x34, 0x0f, 0xbd, 0x94, 0xf4, 0x42, 0x8f,
-	0x45, 0x58, 0x15, 0xa6, 0x1b, 0x6f, 0x1c, 0xef, 0x41, 0x23, 0x88, 0xfd, 0x60, 0xea, 0xa5, 0xd4,
-	0xbc, 0xc2, 0x66, 0x80, 0x68, 0x69, 0x83, 0x38, 0x9d, 0x19, 0xda, 0x1a, 0xb8, 0x2a, 0x86, 0x6a,
-	0x05, 0x32, 0x17, 0x0b, 0xc6, 0xd5, 0x4b, 0x9e, 0xaa, 0x91, 0xad, 0x44, 0x37, 0xba, 0xf2, 0x31,
-	0xaf, 0x0b, 0x6d, 0xb1, 0xce, 0x6c, 0xeb, 0x4c, 0x0f, 0x11, 0xcf, 0x07, 0x66, 0xf7, 0x3e, 0x82,
-	0x77, 0x82, 0x58, 0xa4, 0x4e, 0xe2, 0x9e, 0x06, 0xa9, 0x6a, 0xdb, 0x5d, 0x26, 0x0e, 0x9d, 0xa0,
-	0xac, 0x82, 0xef, 0x68, 0xe9, 0x5e, 0x90, 0xca, 0x16, 0x1e, 0xab, 0x0b, 0x79, 0xc5, 0x67, 0xc1,
-	0x2c, 0x95, 0xbc, 0x55, 0xb0, 0x1a, 0x88, 0xd9, 0xc6, 0xe4, 0xc2, 0x25, 0xaf, 0x7c, 0x99, 0x83,
-	0x2b, 0xb8, 0x1a, 0x93, 0x0b, 0xe7, 0x95, 0x8f, 0x1e, 0xc1, 0x6d, 0xc5, 0x77, 0x3e, 0x91, 0xaa,
-	0x77, 0x8a, 0x35, 0x49, 0x79, 0x2e, 0x89, 0xbe, 0xc8, 0x77, 0x06, 0x20, 0xcf, 0xdd, 0x23, 0xc3,
-	0xf1, 0x77, 0x31, 0x9a, 0x95, 0x63, 0x79, 0xa7, 0xcb, 0x8c, 0xbb, 0x3f, 0x84, 0x76, 0x41, 0x86,
-	0x1a, 0x50, 0xc1, 0xbd, 0xe1, 0xd8, 0x51, 0x4f, 0xa7, 0xfd, 0x03, 0xa7, 0x87, 0xad, 0xd2, 0xde,
-	0x18, 0xee, 0x50, 0x76, 0x26, 0x2f, 0x21, 0x53, 0xca, 0x7c, 0xfd, 0xad, 0xbd, 0xd6, 0x89, 0xfc,
-	0xaf, 0x78, 0xfa, 0xcd, 0xce, 0x59, 0x90, 0x9e, 0xcf, 0x4f, 0x45, 0x02, 0xd8, 0x35, 0x9a, 0xbb,
-	0x4a, 0xf3, 0xb1, 0x7e, 0xba, 0x5f, 0x7c, 0xbc, 0x7b, 0x46, 0x35, 0x76, 0x5a, 0x95, 0xe0, 0x47,
-	0xff, 0x0d, 0x00, 0x00, 0xff, 0xff, 0x30, 0x2a, 0x80, 0x58, 0x75, 0x18, 0x00, 0x00,
+	// 2341 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x58, 0xcd, 0x72, 0xdb, 0xb8,
+	0x1d, 0x8f, 0x64, 0x8b, 0x12, 0xff, 0xfa, 0x30, 0x83, 0x38, 0x09, 0x63, 0xd7, 0xe3, 0x54, 0xd9,
+	0x4e, 0x9d, 0xa4, 0xb1, 0xd3, 0x64, 0x67, 0x77, 0x7b, 0xe8, 0x4c, 0x64, 0x89, 0x4e, 0x38, 0x75,
+	0x25, 0x17, 0x92, 0xbc, 0x6d, 0x2f, 0x1c, 0x5a, 0x84, 0x6c, 0x4e, 0x48, 0x42, 0x01, 0x28, 0xd9,
+	0xde, 0x5b, 0x67, 0xa7, 0x3d, 0xf5, 0xd6, 0x5b, 0x9f, 0xa0, 0x6f, 0xb0, 0xc7, 0xf6, 0x05, 0x76,
+	0xfa, 0x0e, 0xed, 0xa5, 0x4f, 0xb0, 0xe7, 0x0e, 0x00, 0x42, 0x22, 0x9d, 0x34, 0xdb, 0xbd, 0xd8,
+	0xc4, 0xef, 0xff, 0x01, 0xe0, 0x07, 0xfc, 0x3f, 0x20, 0xd8, 0x5a, 0xd0, 0x28, 0xbd, 0xf0, 0xbd,
+	0x19, 0xa3, 0x29, 0xe5, 0x07, 0x01, 0x59, 0x84, 0x13, 0xb2, 0x2f, 0x47, 0xc8, 0x50, 0xb2, 0xad,
+	0x07, 0xe7, 0x94, 0x9e, 0x47, 0xe4, 0x40, 0xa2, 0x67, 0xf3, 0xe9, 0x81, 0x9f, 0x5c, 0x2b, 0x95,
+	0xad, 0x1b, 0xe6, 0x13, 0x1a, 0xc7, 0x34, 0xc9, 0x64, 0x76, 0x51, 0x16, 0x93, 0xd4, 0xcf, 0x24,
+	0xbb, 0x45, 0x09, 0x9d, 0x91, 0x64, 0x1a, 0xd1, 0x4b, 0xef, 0xe7, 0x2f, 0x95, 0x42, 0xfb, 0xef,
+	0x65, 0x80, 0x9e, 0x5c, 0xca, 0xe8, 0x7a, 0x46, 0x50, 0x0b, 0xca, 0x61, 0x60, 0x97, 0x1e, 0x96,
+	0xf6, 0x4c, 0x5c, 0x0e, 0x03, 0xb4, 0x0d, 0xe6, 0x82, 0x24, 0x01, 0x65, 0x5e, 0x18, 0xd8, 0x15,
+	0x09, 0xd7, 0x14, 0xe0, 0x06, 0x68, 0x07, 0x60, 0x29, 0xe4, 0xb6, 0xf1, 0x70, 0x6d, 0xcf, 0xc4,
+	0xa6, 0x96, 0x72, 0x64, 0x43, 0xd5, 0x0f, 0xfc, 0x59, 0x4a, 0x98, 0x5d, 0x96, 0x96, 0x7a, 0x88,
+	0x3e, 0x07, 0xdb, 0x9f, 0x4c, 0xc8, 0x2c, 0xe5, 0xde, 0xd9, 0x3c, 0x7a, 0xeb, 0xc9, 0x25, 0xcd,
+	0x67, 0x81, 0x9f, 0x12, 0x7b, 0xed, 0x61, 0x69, 0xaf, 0x86, 0xef, 0x66, 0xf2, 0xc3, 0x79, 0xf4,
+	0xf6, 0x28, 0xa2, 0x97, 0x63, 0x29, 0x44, 0x3d, 0xd8, 0xd5, 0x86, 0x7e, 0x10, 0x78, 0x8c, 0xc4,
+	0x74, 0x41, 0xf2, 0xe6, 0xdc, 0x5e, 0x97, 0xf6, 0xdb, 0x99, 0x5a, 0x27, 0x08, 0xb0, 0x54, 0x5a,
+	0x39, 0xe1, 0xe8, 0x18, 0x1e, 0x69, 0x2f, 0x41, 0xc8, 0xc8, 0x24, 0xf5, 0x22, 0x7a, 0x1e, 0x4e,
+	0xfc, 0x48, 0x7a, 0xe2, 0x7a, 0x25, 0x55, 0xe9, 0x49, 0x4f, 0xd8, 0x93, 0x9a, 0xc7, 0x4a, 0x51,
+	0x78, 0xe3, 0xca, 0x5d, 0xfb, 0x73, 0xa8, 0xaf, 0x08, 0xe4, 0x68, 0x0f, 0x2a, 0x61, 0x4a, 0x62,
+	0x6e, 0x97, 0x1e, 0xae, 0xed, 0xd5, 0x5f, 0xa0, 0x7d, 0x75, 0x02, 0xfb, 0x2b, 0x1d, 0xac, 0x14,
+	0xda, 0xff, 0x28, 0x41, 0xed, 0x24, 0xee, 0xd2, 0x64, 0x1a, 0x9e, 0x23, 0x04, 0xeb, 0x89, 0x1f,
+	0x93, 0x8c, 0x7a, 0xf9, 0x8d, 0x9e, 0xc2, 0x7a, 0x7a, 0x3d, 0x23, 0x92, 0xbd, 0xd6, 0x8b, 0xfb,
+	0xda, 0x93, 0xb6, 0xd9, 0x3f, 0x89, 0xa5, 0x3b, 0xa9, 0x24, 0xd8, 0x26, 0x89, 0x7f, 0x16, 0x91,
+	0x20, 0xa3, 0x50, 0x0f, 0xd1, 0x2e, 0xd4, 0xb9, 0x1f, 0xcf, 0x22, 0xe2, 0x4d, 0x19, 0x79, 0x27,
+	0x09, 0x6a, 0x62, 0x50, 0xd0, 0x11, 0x23, 0xef, 0xda, 0x5f, 0x80, 0xa1, 0x5c, 0xa1, 0x3a, 0x54,
+	0xbb, 0x83, 0x71, 0x7f, 0xe4, 0x60, 0xeb, 0x16, 0x32, 0xa1, 0xf2, 0xba, 0x33, 0x7e, 0xed, 0x58,
+	0x25, 0xf1, 0x39, 0x1c, 0x75, 0x46, 0x8e, 0x55, 0x56, 0x2a, 0xfd, 0x91, 0xf3, 0xdb, 0x91, 0xb5,
+	0xd6, 0xfe, 0x4b, 0x09, 0x9a, 0x27, 0xf1, 0x6b, 0x46, 0xe7, 0xb3, 0x6c, 0x1f, 0x3b, 0x00, 0xe7,
+	0x62, 0xe8, 0xe5, 0x76, 0x63, 0x4a, 0xa4, 0x2f, 0xb6, 0xb4, 0x14, 0xcb, 0xa5, 0x94, 0xe5, 0x52,
+	0x94, 0x58, 0xac, 0xe4, 0x23, 0x9b, 0x78, 0x02, 0xd5, 0x98, 0xa4, 0x2c, 0x9c, 0x88, 0x13, 0x16,
+	0xc4, 0x5a, 0x37, 0xe9, 0xc0, 0x5a, 0xa1, 0xfd, 0x87, 0x32, 0x98, 0x1a, 0xe5, 0xef, 0x5d, 0xe9,
+	0x1f, 0x43, 0x23, 0x20, 0x53, 0x7f, 0x1e, 0xa5, 0xf9, 0x45, 0xd4, 0x33, 0x4c, 0x2e, 0x63, 0x17,
+	0xaa, 0x72, 0x4d, 0x7a, 0x19, 0x87, 0x95, 0xff, 0x7c, 0xf7, 0xed, 0x4e, 0x09, 0x6b, 0x14, 0x3d,
+	0x81, 0xa6, 0xb0, 0xf5, 0xe8, 0x82, 0x30, 0x16, 0x06, 0x44, 0xdd, 0x3a, 0xad, 0xd6, 0x10, 0xb2,
+	0x41, 0x26, 0x42, 0xcf, 0xc0, 0x90, 0x66, 0xdc, 0xae, 0xc8, 0x85, 0xdf, 0x5d, 0x2d, 0x3c, 0x47,
+	0x1c, 0xce, 0x94, 0xf2, 0x1b, 0x35, 0xbe, 0x67, 0xa3, 0xe8, 0x01, 0xd4, 0x62, 0xff, 0xca, 0xe3,
+	0x6f, 0xc9, 0xa5, 0xbc, 0xad, 0x4d, 0x5c, 0x8d, 0xfd, 0xab, 0xe1, 0x5b, 0x72, 0xd9, 0xfe, 0x67,
+	0x09, 0x2a, 0x6e, 0xec, 0x9f, 0x93, 0x0f, 0xde, 0x2c, 0x1b, 0xaa, 0x0b, 0xc2, 0x78, 0x48, 0x13,
+	0x1d, 0x9a, 0xd9, 0x50, 0x68, 0x5f, 0xf8, 0xfc, 0x42, 0xee, 0xdb, 0xc4, 0xf2, 0x1b, 0x3d, 0x06,
+	0x2b, 0x4c, 0x78, 0xea, 0x47, 0x91, 0x27, 0x6e, 0x7c, 0x1a, 0xc6, 0x6a, 0xc3, 0x26, 0xde, 0xc8,
+	0xf0, 0x5e, 0x06, 0x8b, 0x7c, 0x11, 0x72, 0xcf, 0x9f, 0xa4, 0xe1, 0x82, 0xc8, 0x7c, 0x51, 0xc3,
+	0xb5, 0x90, 0x77, 0xe4, 0x58, 0x30, 0x1f, 0x72, 0x4f, 0x64, 0xae, 0x30, 0x4d, 0x49, 0x60, 0x1b,
+	0x52, 0x5e, 0x0f, 0x79, 0x57, 0x43, 0x62, 0x47, 0x21, 0xf7, 0x16, 0x7e, 0x14, 0x06, 0x59, 0xfc,
+	0x55, 0x43, 0x7e, 0x2a, 0x86, 0xed, 0x67, 0x60, 0xc8, 0x0d, 0x71, 0xf4, 0x08, 0x2a, 0xa1, 0xf8,
+	0xca, 0x42, 0xac, 0xa9, 0x09, 0x92, 0x62, 0xac, 0x64, 0xed, 0x7f, 0x57, 0xa1, 0x29, 0x81, 0x1e,
+	0xbd, 0x4c, 0x22, 0xea, 0x07, 0xef, 0x5d, 0x04, 0x4d, 0x4c, 0x39, 0x47, 0x8c, 0x05, 0x6b, 0x73,
+	0x16, 0x65, 0xbb, 0x17, 0x9f, 0x02, 0x99, 0xb0, 0x49, 0x16, 0x35, 0xe2, 0x13, 0x0d, 0xa0, 0x15,
+	0x64, 0x3e, 0x3d, 0x9e, 0x8a, 0x4c, 0x51, 0x91, 0x01, 0xba, 0x57, 0x58, 0x87, 0x9e, 0xb6, 0x38,
+	0x1a, 0x0a, 0x7d, 0xdc, 0x0c, 0xf2, 0x43, 0xf4, 0x08, 0x9a, 0x72, 0xcd, 0x9e, 0x3e, 0x13, 0x43,
+	0x4e, 0xdf, 0x90, 0xe0, 0x69, 0x76, 0x30, 0x8f, 0xc1, 0xd2, 0x56, 0x24, 0xf0, 0xce, 0xae, 0x45,
+	0xae, 0x53, 0x67, 0xbe, 0xb1, 0xc2, 0x0f, 0x05, 0x8c, 0xde, 0x80, 0xc1, 0x88, 0xcf, 0x69, 0x62,
+	0xd7, 0xe4, 0xc2, 0x9e, 0xff, 0x1f, 0x0b, 0x3b, 0xf2, 0xc3, 0x68, 0xce, 0x08, 0x96, 0x76, 0x38,
+	0xb3, 0x47, 0x3f, 0x85, 0x0d, 0x3f, 0x08, 0xc2, 0x34, 0xa4, 0x89, 0x1f, 0x79, 0x61, 0x32, 0xa5,
+	0xb6, 0x29, 0xd7, 0xd6, 0x5a, 0xc1, 0x6e, 0x32, 0xa5, 0x2a, 0xc7, 0x2c, 0x88, 0x37, 0x91, 0x37,
+	0xd4, 0x06, 0x79, 0x74, 0x20, 0xa0, 0x2c, 0x2f, 0x6c, 0x83, 0x19, 0x51, 0x91, 0x62, 0x83, 0x90,
+	0xd9, 0x75, 0x55, 0x48, 0x24, 0xd0, 0x0b, 0x19, 0x72, 0xa1, 0xae, 0x08, 0x50, 0x74, 0x36, 0xbe,
+	0x97, 0x4e, 0x79, 0xa1, 0xfc, 0x94, 0x28, 0x3a, 0x41, 0x1a, 0x2b, 0x2e, 0xb7, 0xc1, 0x9c, 0x86,
+	0x11, 0xf1, 0x78, 0xf8, 0x15, 0xb1, 0x9b, 0x92, 0x9f, 0x9a, 0x00, 0x86, 0xe1, 0x57, 0xa4, 0xfd,
+	0x4d, 0x09, 0xd0, 0xfb, 0xc7, 0x81, 0x36, 0xc1, 0xea, 0x0d, 0xbe, 0xec, 0x1f, 0x0f, 0x3a, 0x3d,
+	0x6f, 0xdc, 0xff, 0x55, 0x7f, 0xf0, 0x65, 0xdf, 0xba, 0x85, 0xee, 0x01, 0x5a, 0xa2, 0xc3, 0x71,
+	0xb7, 0xeb, 0x38, 0x3d, 0xa7, 0x67, 0x95, 0x0a, 0x38, 0x76, 0x7e, 0x33, 0x76, 0x86, 0x23, 0xa7,
+	0x67, 0x95, 0x0b, 0x5e, 0x86, 0xa3, 0x0e, 0x16, 0xe8, 0x1a, 0xba, 0x03, 0x1b, 0x4b, 0xf4, 0xa8,
+	0xe3, 0x1e, 0x3b, 0x3d, 0x6b, 0x1d, 0xd9, 0xb0, 0x99, 0x9b, 0x70, 0x38, 0x3e, 0x39, 0x19, 0x48,
+	0xf5, 0x4a, 0xc1, 0x79, 0xb7, 0xd3, 0xef, 0x3a, 0xc7, 0xc2, 0xc2, 0x68, 0xff, 0xa9, 0x04, 0x5b,
+	0xff, 0xfb, 0xbc, 0x50, 0x03, 0x6a, 0xfd, 0x81, 0xe7, 0x60, 0x3c, 0x10, 0x89, 0x7b, 0x03, 0xea,
+	0x6e, 0xff, 0xb4, 0x73, 0xec, 0xf6, 0xbc, 0x31, 0x3e, 0xb6, 0x4a, 0x02, 0xe8, 0x39, 0xa7, 0x6e,
+	0xd7, 0xf1, 0x0e, 0xc7, 0xc3, 0xdf, 0x59, 0x65, 0x31, 0x8d, 0xdb, 0x1f, 0x8e, 0x8f, 0x8e, 0xdc,
+	0xae, 0xeb, 0xf4, 0x47, 0xde, 0xf0, 0xa4, 0xd3, 0x75, 0xac, 0x35, 0x74, 0x1b, 0x9a, 0x19, 0x01,
+	0x99, 0xb3, 0x75, 0xd4, 0x04, 0x73, 0xb5, 0x90, 0x4a, 0xfb, 0xcf, 0x9a, 0xc2, 0xc2, 0x11, 0x08,
+	0x43, 0xf7, 0xd7, 0x9d, 0xd7, 0x4e, 0x8e, 0x3f, 0x04, 0x2d, 0x05, 0xb9, 0xfd, 0x4e, 0x77, 0xe4,
+	0x9e, 0x8a, 0x3a, 0xb2, 0x09, 0x96, 0xc2, 0x24, 0xd2, 0x19, 0xb9, 0xfd, 0xd7, 0x56, 0x19, 0x59,
+	0xd0, 0xc8, 0xa1, 0x8e, 0x62, 0x4d, 0x21, 0xd8, 0x39, 0x75, 0xb0, 0x54, 0x5b, 0x5f, 0x39, 0x54,
+	0xa0, 0x5c, 0xce, 0x2f, 0xa1, 0x55, 0xa0, 0x85, 0xa3, 0xa7, 0xba, 0xfe, 0x96, 0x8b, 0xd9, 0xb6,
+	0xa0, 0xa6, 0x4b, 0xf0, 0x37, 0x15, 0x58, 0x3f, 0xa1, 0x2c, 0x45, 0xf7, 0xa1, 0x3a, 0xa3, 0x2c,
+	0xf5, 0x12, 0x2a, 0x13, 0x44, 0x13, 0x1b, 0x62, 0xd8, 0xa7, 0x68, 0x13, 0x2a, 0x91, 0x7f, 0x46,
+	0xa2, 0x2c, 0x4b, 0xa8, 0x01, 0x7a, 0x9c, 0x55, 0xe6, 0x35, 0x79, 0x53, 0x57, 0x19, 0x9d, 0xb2,
+	0x54, 0xfe, 0xc9, 0xd5, 0xe5, 0x5f, 0x40, 0xdd, 0x0f, 0xe2, 0x30, 0x29, 0xa4, 0x0a, 0x7b, 0x3f,
+	0xeb, 0xdf, 0x3a, 0x42, 0x24, 0x29, 0xdc, 0x97, 0xed, 0x03, 0x06, 0x7f, 0x89, 0x08, 0x53, 0x3a,
+	0x23, 0x4c, 0x5a, 0xce, 0xb9, 0xcc, 0x0a, 0x39, 0xd3, 0xc1, 0x8c, 0xb0, 0xa1, 0x94, 0x68, 0x53,
+	0xba, 0x44, 0x44, 0x18, 0xa8, 0x06, 0xd3, 0xcb, 0x12, 0xa9, 0x89, 0x6b, 0x0a, 0x70, 0x03, 0x41,
+	0xd1, 0x8c, 0x10, 0xc6, 0xed, 0xda, 0x8d, 0x82, 0x24, 0x97, 0x4f, 0x08, 0x13, 0x1f, 0x58, 0xe9,
+	0x88, 0x8a, 0xcd, 0xae, 0xbc, 0x99, 0x3f, 0x79, 0x4b, 0x52, 0x2e, 0xa3, 0xdf, 0xc0, 0x26, 0xbb,
+	0x3a, 0x51, 0x80, 0x48, 0xd8, 0xec, 0x2a, 0x4b, 0x47, 0x20, 0x85, 0x55, 0x76, 0xa5, 0xd2, 0xd0,
+	0x36, 0x98, 0xec, 0xca, 0x23, 0x8c, 0x51, 0xc6, 0x65, 0xc8, 0x1b, 0xb8, 0xc6, 0xae, 0x1c, 0x39,
+	0x16, 0x6e, 0xd3, 0x95, 0xdb, 0x86, 0x72, 0x9b, 0xe6, 0xdd, 0xa6, 0xda, 0x6d, 0x53, 0xb9, 0x4d,
+	0x57, 0x6e, 0xd3, 0xa5, 0xdb, 0x96, 0x72, 0x9b, 0x6a, 0xb7, 0xcf, 0xa1, 0x46, 0xa7, 0x33, 0x4f,
+	0x1c, 0x9e, 0xbd, 0xf1, 0xb0, 0x24, 0x77, 0x97, 0x6f, 0x7a, 0xb5, 0x10, 0x57, 0xe9, 0x74, 0x26,
+	0xb6, 0xb9, 0xf5, 0x0a, 0x6a, 0x7a, 0xcb, 0x45, 0xd6, 0x4a, 0x37, 0x58, 0xcb, 0x5d, 0x91, 0x72,
+	0xfe, 0x8a, 0xb4, 0x39, 0xd4, 0xf4, 0x99, 0x8b, 0xee, 0x68, 0x15, 0x01, 0x16, 0x34, 0x9c, 0xd1,
+	0x1b, 0x07, 0xf7, 0x9d, 0x91, 0xd7, 0xef, 0xbb, 0x56, 0xa9, 0x80, 0x8c, 0xfb, 0xae, 0x6a, 0xa7,
+	0x4e, 0x06, 0x7d, 0x6f, 0x70, 0x3c, 0xb2, 0xd6, 0x96, 0x83, 0xfe, 0x58, 0x05, 0xde, 0xa9, 0x23,
+	0x14, 0x85, 0xac, 0x92, 0x1b, 0xf6, 0xc7, 0x96, 0xd1, 0x7e, 0x0a, 0x15, 0x31, 0x29, 0x47, 0xed,
+	0x62, 0xbf, 0xd9, 0xc8, 0x1f, 0xa6, 0xbe, 0xe6, 0x7f, 0xad, 0x83, 0xa1, 0xfa, 0x4f, 0x74, 0x77,
+	0x55, 0x04, 0x75, 0xbb, 0x22, 0x6a, 0xe1, 0x83, 0x5c, 0xab, 0xb9, 0x14, 0xa8, 0x0b, 0xfc, 0x00,
+	0xd6, 0x19, 0xa5, 0x69, 0xb1, 0x13, 0x92, 0x10, 0x6a, 0x83, 0x39, 0xf3, 0x19, 0x49, 0x52, 0xc1,
+	0xd7, 0x7a, 0xde, 0xb4, 0xa6, 0x70, 0x79, 0xd9, 0x5a, 0x99, 0x8e, 0x66, 0x6f, 0x53, 0xb0, 0xb7,
+	0xec, 0x95, 0x94, 0xf0, 0x44, 0x45, 0xdb, 0x0e, 0x18, 0xea, 0xfd, 0xa0, 0xde, 0x1a, 0x5a, 0x29,
+	0x03, 0xd1, 0x36, 0x54, 0x62, 0x1a, 0x90, 0x48, 0x15, 0x48, 0x2d, 0x55, 0x18, 0x7a, 0x0e, 0xd6,
+	0x85, 0xcf, 0x82, 0x4b, 0x9f, 0xad, 0x0a, 0x69, 0x35, 0xaf, 0xb7, 0xa1, 0xc5, 0xba, 0xa4, 0x3e,
+	0x07, 0x6b, 0x1a, 0xb2, 0xb8, 0x60, 0x51, 0x2b, 0x58, 0x68, 0xb1, 0xb6, 0x78, 0x06, 0x86, 0xac,
+	0x35, 0x2a, 0x10, 0xea, 0x2f, 0x5a, 0x85, 0xec, 0xc2, 0x97, 0xeb, 0x55, 0x4a, 0xa2, 0x4d, 0xe4,
+	0x84, 0x85, 0x7e, 0xe4, 0x25, 0xf3, 0xf8, 0x8c, 0x30, 0x19, 0x21, 0x4b, 0xef, 0x0d, 0x25, 0xeb,
+	0x4b, 0x91, 0xe0, 0x72, 0xf5, 0xd2, 0xb2, 0x0b, 0x5c, 0x2e, 0x1f, 0x5c, 0xbb, 0xab, 0x17, 0x55,
+	0x3d, 0xaf, 0xb1, 0x7c, 0x58, 0x21, 0x58, 0x5f, 0x44, 0x7e, 0x22, 0xe3, 0xa9, 0x89, 0xe5, 0xb7,
+	0x28, 0xcd, 0xb1, 0x3f, 0x11, 0xef, 0x25, 0x46, 0xb8, 0x8a, 0x26, 0x13, 0x43, 0xec, 0x4f, 0x3a,
+	0x0a, 0x41, 0x8f, 0xa0, 0x11, 0xce, 0x16, 0x9f, 0x2e, 0x35, 0x44, 0x4c, 0x99, 0x6f, 0x6e, 0xe1,
+	0xba, 0x40, 0x8b, 0x4a, 0x9f, 0x2d, 0x95, 0x36, 0x72, 0x4a, 0x9f, 0x69, 0xa5, 0x4f, 0xa0, 0x79,
+	0x41, 0x79, 0xea, 0xf9, 0x49, 0xa0, 0x42, 0xf0, 0xae, 0xd6, 0x12, 0x70, 0x27, 0x09, 0x64, 0x94,
+	0xed, 0x00, 0x90, 0xab, 0x94, 0xf9, 0x9e, 0xcf, 0xce, 0xb9, 0x7d, 0x5f, 0x3d, 0x11, 0x24, 0xd2,
+	0x61, 0xe7, 0x1c, 0xbd, 0x82, 0xe6, 0x8c, 0xd1, 0xab, 0xeb, 0xe5, 0x54, 0x77, 0x24, 0xd5, 0xdb,
+	0xc5, 0x87, 0xd4, 0xfe, 0x89, 0xd0, 0xc9, 0x26, 0xc6, 0x8d, 0x59, 0x6e, 0x74, 0x33, 0xe5, 0x5a,
+	0x3f, 0x20, 0xe5, 0xbe, 0x2a, 0xa6, 0xdc, 0xdb, 0x1f, 0x4f, 0xb9, 0x9a, 0xff, 0x7c, 0xe6, 0xdd,
+	0x59, 0x36, 0x5f, 0xf7, 0x0a, 0x57, 0x38, 0xeb, 0xa8, 0x5c, 0x68, 0x4d, 0x68, 0x92, 0x88, 0x47,
+	0x67, 0x36, 0x07, 0x92, 0x73, 0x6c, 0xeb, 0x39, 0xba, 0x4a, 0xfa, 0xa1, 0x69, 0x9a, 0x93, 0xbc,
+	0x0c, 0xfd, 0x0c, 0x8c, 0xc9, 0x9c, 0xa7, 0x34, 0xb6, 0x5f, 0x49, 0x86, 0x36, 0xf7, 0xd5, 0xaf,
+	0x07, 0xfb, 0xfa, 0xd7, 0x83, 0xfd, 0x4e, 0x72, 0x8d, 0x33, 0x1d, 0xf4, 0x05, 0xc0, 0x2c, 0xce,
+	0xfa, 0x33, 0x6e, 0x7f, 0x5d, 0x92, 0x26, 0xb7, 0x6f, 0xbe, 0x2d, 0xf8, 0x61, 0xe5, 0x5f, 0xdf,
+	0x7d, 0xbb, 0x73, 0x0b, 0x9b, 0xb3, 0xe5, 0x03, 0xea, 0x18, 0x36, 0x54, 0x77, 0xa6, 0xfb, 0x4c,
+	0x6e, 0xff, 0xb1, 0xf4, 0x91, 0xe2, 0x7a, 0x58, 0x17, 0x2e, 0x0c, 0xd5, 0x5d, 0xe3, 0x56, 0x58,
+	0xa8, 0xcf, 0x5b, 0x5f, 0x97, 0xa1, 0x91, 0x3f, 0xbb, 0x8f, 0x27, 0xdd, 0x5d, 0xa8, 0x67, 0xc2,
+	0x55, 0x7a, 0xc2, 0x10, 0xac, 0x7e, 0xb0, 0xd8, 0x01, 0x98, 0x5c, 0xf8, 0x49, 0x42, 0x22, 0x61,
+	0xbe, 0xa6, 0x1e, 0x94, 0x19, 0xe2, 0x06, 0x68, 0x0f, 0x2c, 0x2d, 0x56, 0xef, 0xce, 0x2c, 0x51,
+	0x35, 0x71, 0x2b, 0xc3, 0xe5, 0x1b, 0xcc, 0x0d, 0xd0, 0x01, 0xdc, 0xd1, 0x9a, 0x29, 0x61, 0x71,
+	0x98, 0xf8, 0xa2, 0xbd, 0xcd, 0x7e, 0xf3, 0x40, 0x99, 0x68, 0xb4, 0x92, 0xa0, 0xbb, 0x60, 0xd0,
+	0x64, 0x2e, 0x1c, 0x1a, 0xd2, 0x61, 0x85, 0x26, 0x73, 0x37, 0x40, 0x9f, 0x40, 0x4b, 0xc0, 0x9c,
+	0x70, 0x91, 0x31, 0x74, 0xf9, 0x6d, 0xe2, 0x06, 0x4d, 0xe6, 0x43, 0x05, 0xba, 0xc1, 0xa1, 0x29,
+	0x22, 0x59, 0xee, 0xbf, 0x7d, 0x00, 0x55, 0x75, 0xa5, 0x45, 0xfc, 0x14, 0x72, 0x79, 0xab, 0x78,
+	0xe5, 0x75, 0x36, 0xff, 0xdb, 0x1a, 0x6c, 0x0e, 0xc3, 0x78, 0x1e, 0xf9, 0x29, 0xe9, 0x44, 0x3e,
+	0x8b, 0x31, 0x79, 0x37, 0x27, 0x3c, 0x7d, 0xef, 0x81, 0xf3, 0x23, 0x30, 0xc3, 0x24, 0x08, 0x27,
+	0x7e, 0x4a, 0xf5, 0x4f, 0x30, 0x2b, 0x40, 0xd4, 0xb3, 0x30, 0x49, 0xa7, 0x9a, 0x36, 0x13, 0x1b,
+	0x62, 0xa8, 0x76, 0x20, 0x53, 0xb5, 0x60, 0x5c, 0x3d, 0xe3, 0xd5, 0x63, 0xaf, 0x31, 0xcb, 0xaa,
+	0x9c, 0x7c, 0xc9, 0xb7, 0xa1, 0x29, 0xf6, 0xb9, 0x3a, 0x3a, 0xc5, 0x54, 0x9d, 0x26, 0xf3, 0x9e,
+	0x3e, 0xbd, 0x97, 0x70, 0x2f, 0x4c, 0x44, 0x66, 0x25, 0xde, 0x59, 0x98, 0xaa, 0x9a, 0xed, 0x31,
+	0x11, 0x93, 0x82, 0xb2, 0x0a, 0xbe, 0x93, 0x49, 0x0f, 0xc3, 0x54, 0xd6, 0x6f, 0xac, 0xba, 0xf1,
+	0x4a, 0xc0, 0xc2, 0x69, 0x2a, 0x79, 0xab, 0x60, 0x35, 0x10, 0xab, 0x4d, 0xc8, 0xa5, 0x47, 0xde,
+	0x05, 0x32, 0x45, 0x57, 0xb0, 0x91, 0x90, 0x4b, 0xe7, 0x9d, 0x78, 0x8a, 0xdf, 0x56, 0x7c, 0xe7,
+	0xf3, 0xac, 0x7a, 0xa4, 0x6c, 0x48, 0xca, 0x73, 0x39, 0xf6, 0x0d, 0x98, 0x22, 0x52, 0xd5, 0xc9,
+	0x82, 0x8c, 0xbb, 0x27, 0x9a, 0xe3, 0x0f, 0x31, 0x2a, 0x03, 0x5e, 0x6a, 0xcb, 0x86, 0x6e, 0x65,
+	0xdc, 0xfe, 0x09, 0x34, 0x0b, 0x32, 0x64, 0x42, 0x05, 0x77, 0xdc, 0xa1, 0xa3, 0x7e, 0x37, 0xe9,
+	0x1e, 0x3b, 0x1d, 0x6c, 0x95, 0x0e, 0x87, 0x70, 0x87, 0xb2, 0x73, 0xd9, 0x81, 0x4c, 0x28, 0x0b,
+	0xb2, 0xb9, 0x0e, 0x1b, 0xa7, 0xf2, 0xbf, 0xe2, 0xe9, 0xf7, 0xfb, 0xe7, 0x61, 0x7a, 0x31, 0x3f,
+	0x13, 0x09, 0xe0, 0x40, 0x6b, 0x1e, 0x28, 0xcd, 0x67, 0xd9, 0xef, 0x76, 0x8b, 0x4f, 0x0f, 0xce,
+	0x69, 0x86, 0x9d, 0x19, 0x12, 0x7c, 0xf9, 0xdf, 0x00, 0x00, 0x00, 0xff, 0xff, 0x8e, 0x96, 0xa4,
+	0xa3, 0x51, 0x14, 0x00, 0x00,
 }
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/events.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/events.pb.go
index f51a7b7..2dc1826 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/events.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/events.pb.go
@@ -116,11 +116,12 @@
 type EventSubCategory_Types int32
 
 const (
-	EventSubCategory_PON EventSubCategory_Types = 0
-	EventSubCategory_OLT EventSubCategory_Types = 1
-	EventSubCategory_ONT EventSubCategory_Types = 2
-	EventSubCategory_ONU EventSubCategory_Types = 3
-	EventSubCategory_NNI EventSubCategory_Types = 4
+	EventSubCategory_PON  EventSubCategory_Types = 0
+	EventSubCategory_OLT  EventSubCategory_Types = 1
+	EventSubCategory_ONT  EventSubCategory_Types = 2
+	EventSubCategory_ONU  EventSubCategory_Types = 3
+	EventSubCategory_NNI  EventSubCategory_Types = 4
+	EventSubCategory_NONE EventSubCategory_Types = 5
 )
 
 var EventSubCategory_Types_name = map[int32]string{
@@ -129,14 +130,16 @@
 	2: "ONT",
 	3: "ONU",
 	4: "NNI",
+	5: "NONE",
 }
 
 var EventSubCategory_Types_value = map[string]int32{
-	"PON": 0,
-	"OLT": 1,
-	"ONT": 2,
-	"ONU": 3,
-	"NNI": 4,
+	"PON":  0,
+	"OLT":  1,
+	"ONT":  2,
+	"ONU":  3,
+	"NNI":  4,
+	"NONE": 5,
 }
 
 func (x EventSubCategory_Types) String() string {
@@ -1149,85 +1152,86 @@
 func init() { proto.RegisterFile("voltha_protos/events.proto", fileDescriptor_e63e6c07044fd2c4) }
 
 var fileDescriptor_e63e6c07044fd2c4 = []byte{
-	// 1274 bytes of a gzipped FileDescriptorProto
-	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xb4, 0x56, 0xdf, 0x6e, 0xdb, 0xb6,
-	0x17, 0xb6, 0xe4, 0xff, 0x47, 0x4e, 0xa2, 0xb0, 0xbf, 0xdf, 0xe6, 0xba, 0x5b, 0x9b, 0x7a, 0xd8,
-	0x10, 0xb4, 0xa8, 0x8c, 0x69, 0x05, 0x1a, 0xa4, 0x18, 0xb6, 0xd6, 0xf5, 0x1a, 0xa1, 0x8b, 0xed,
-	0x29, 0x4e, 0x80, 0xee, 0xc6, 0x60, 0x24, 0xc6, 0x11, 0x62, 0x5b, 0x02, 0x49, 0x1b, 0xcd, 0x03,
-	0xec, 0x7a, 0x0f, 0xb2, 0xe7, 0xd8, 0xdd, 0xde, 0x60, 0x18, 0xf6, 0x12, 0x7b, 0x80, 0x81, 0x7f,
-	0x64, 0x4b, 0x6e, 0x8a, 0x5e, 0x04, 0xbb, 0x12, 0x79, 0x78, 0x3e, 0x9e, 0xef, 0x7c, 0xe2, 0x39,
-	0x24, 0xb4, 0x96, 0xf1, 0x94, 0x5f, 0xe2, 0x71, 0x42, 0x63, 0x1e, 0xb3, 0x0e, 0x59, 0x92, 0x39,
-	0x67, 0x8e, 0x9c, 0xa1, 0x8a, 0x5a, 0x6b, 0x35, 0xf3, 0x3e, 0x33, 0xc2, 0xb1, 0xf2, 0x68, 0x7d,
-	0x36, 0x89, 0xe3, 0xc9, 0x94, 0x74, 0x70, 0x12, 0x75, 0xf0, 0x7c, 0x1e, 0x73, 0xcc, 0xa3, 0x78,
-	0xae, 0xf1, 0xad, 0x07, 0x7a, 0x55, 0xce, 0xce, 0x17, 0x17, 0x1d, 0x1e, 0xcd, 0x08, 0xe3, 0x78,
-	0x96, 0x68, 0x87, 0x8d, 0xe0, 0x41, 0x3c, 0x9b, 0xc5, 0x73, 0xb5, 0xd6, 0x7e, 0x0e, 0x3b, 0xdd,
-	0x78, 0x7e, 0x11, 0x4d, 0x7a, 0x82, 0xd2, 0xe8, 0x3a, 0x21, 0xed, 0x7d, 0x28, 0x8b, 0x2f, 0x43,
-	0x55, 0x28, 0xe2, 0x30, 0xb4, 0x0b, 0x08, 0xa0, 0x42, 0xc9, 0x2c, 0x5e, 0x12, 0xdb, 0x10, 0xe3,
-	0x45, 0x12, 0x62, 0x4e, 0x6c, 0xb3, 0x7d, 0x09, 0x56, 0x06, 0x8c, 0xbe, 0x86, 0x12, 0xbf, 0x4e,
-	0x48, 0xd3, 0xd8, 0x33, 0xf6, 0xb7, 0xdd, 0xcf, 0x1d, 0x15, 0xd6, 0xd9, 0xd8, 0xdf, 0x91, 0x9b,
-	0xfb, 0xd2, 0x15, 0x21, 0x28, 0x5d, 0x62, 0x76, 0xd9, 0x34, 0xf7, 0x8c, 0xfd, 0xba, 0x2f, 0xc7,
-	0xc2, 0x16, 0x62, 0x8e, 0x9b, 0x45, 0x65, 0x13, 0xe3, 0xf6, 0x23, 0x68, 0xbc, 0x49, 0xa2, 0x35,
-	0xc7, 0x56, 0xca, 0xb1, 0x0e, 0x65, 0x36, 0x8d, 0x02, 0x62, 0x17, 0x50, 0x05, 0x4c, 0xce, 0x6c,
-	0xa3, 0xfd, 0x9b, 0x09, 0xdb, 0xc7, 0x84, 0xd3, 0x28, 0x38, 0x26, 0x1c, 0xbf, 0xc2, 0x1c, 0xa3,
-	0xff, 0x41, 0x99, 0x47, 0x7c, 0xaa, 0xa8, 0xd5, 0x7d, 0x35, 0x41, 0xdb, 0x02, 0x20, 0x43, 0x1b,
-	0xbe, 0xc9, 0x19, 0x7a, 0x04, 0xbb, 0xd3, 0x78, 0x12, 0x05, 0x78, 0x3a, 0x0e, 0xc9, 0x32, 0x0a,
-	0xc8, 0x38, 0x0a, 0x35, 0x8b, 0x1d, 0xbd, 0xf0, 0x4a, 0xda, 0xbd, 0x10, 0xdd, 0x83, 0x3a, 0x23,
-	0x34, 0xc2, 0xd3, 0xf1, 0x3c, 0x6e, 0x96, 0xa4, 0x4f, 0x4d, 0x19, 0xfa, 0xb1, 0x58, 0x5c, 0x6f,
-	0x50, 0x56, 0x8b, 0x61, 0x8a, 0xfc, 0x16, 0xaa, 0x41, 0x3c, 0xe7, 0xe4, 0x1d, 0x6f, 0x56, 0xf6,
-	0x8a, 0xfb, 0x96, 0xfb, 0x45, 0x2a, 0x54, 0x9e, 0xb4, 0xd0, 0x4d, 0x78, 0xf5, 0xe6, 0x9c, 0x5e,
-	0xfb, 0x29, 0x46, 0xa8, 0xb3, 0x58, 0x44, 0x61, 0xb3, 0xaa, 0xd4, 0x11, 0xe3, 0xd6, 0x21, 0x34,
-	0xb2, 0xce, 0xc8, 0x86, 0xe2, 0x15, 0xb9, 0xd6, 0xc9, 0x8a, 0xa1, 0x10, 0x60, 0x89, 0xa7, 0x0b,
-	0xa2, 0x85, 0x56, 0x93, 0x43, 0xf3, 0xc0, 0x68, 0xff, 0x6a, 0x80, 0xad, 0x02, 0x9f, 0x09, 0xdb,
-	0x10, 0x47, 0x94, 0xa1, 0xef, 0xa0, 0x3a, 0x93, 0x36, 0xd6, 0x34, 0x24, 0xc7, 0x2f, 0xf3, 0x1c,
-	0xd7, 0xae, 0xda, 0xc0, 0x34, 0x4b, 0x8d, 0x12, 0x8c, 0xb2, 0x0b, 0x1f, 0x63, 0x64, 0x66, 0x19,
-	0xfd, 0x6e, 0xc0, 0xae, 0x02, 0x7b, 0xf3, 0x8b, 0x98, 0xce, 0xe4, 0x61, 0x47, 0x2e, 0xd4, 0x44,
-	0x45, 0xc8, 0x93, 0x21, 0xb6, 0xb1, 0xdc, 0x4f, 0x6e, 0xd6, 0xcd, 0x5f, 0xf9, 0xa1, 0xef, 0xd7,
-	0x69, 0x98, 0x32, 0x8d, 0xaf, 0xf2, 0x90, 0xcc, 0xfe, 0xff, 0x41, 0x1e, 0x7f, 0x19, 0x50, 0x4b,
-	0x0f, 0x2d, 0x72, 0x72, 0xb5, 0xd1, 0x4a, 0x79, 0x64, 0x0f, 0x75, 0xae, 0x30, 0xd6, 0x67, 0xd3,
-	0x94, 0x67, 0xf3, 0x10, 0x6a, 0x09, 0x25, 0x17, 0xd1, 0x3b, 0xc2, 0x9a, 0x45, 0x99, 0xcb, 0xfd,
-	0xcd, 0x3d, 0x9c, 0xa1, 0x76, 0x50, 0x39, 0xac, 0xfc, 0x5b, 0xa7, 0xb0, 0x95, 0x5b, 0xba, 0x21,
-	0x0b, 0x27, 0x9b, 0x85, 0xe5, 0x36, 0x3f, 0xf4, 0xbb, 0xb3, 0xf9, 0xfd, 0x62, 0x40, 0x3d, 0x8d,
-	0xed, 0xde, 0x22, 0x41, 0x55, 0x7c, 0x07, 0x00, 0xb2, 0x90, 0xc7, 0xba, 0xf6, 0x45, 0x8a, 0x77,
-	0x3f, 0xf8, 0xbb, 0xfc, 0xba, 0x74, 0x16, 0xff, 0xbb, 0xfd, 0x8f, 0x01, 0x96, 0xaa, 0x4b, 0x25,
-	0xf5, 0x03, 0xb0, 0x28, 0x61, 0xf1, 0x82, 0xaa, 0xfa, 0x53, 0x59, 0x42, 0x6a, 0xf2, 0x42, 0x51,
-	0xe7, 0xba, 0x3c, 0x65, 0x1f, 0x1e, 0xcf, 0xf1, 0x2c, 0x2d, 0x8c, 0x9d, 0x70, 0xbd, 0x51, 0x1f,
-	0xcf, 0x08, 0xda, 0x03, 0x2b, 0x24, 0x2c, 0xa0, 0x51, 0x22, 0xc2, 0xea, 0x6e, 0x90, 0x35, 0xa1,
-	0xc3, 0x75, 0x3d, 0x97, 0x24, 0xeb, 0xbd, 0x94, 0x75, 0x86, 0xd4, 0xcd, 0xc5, 0x7c, 0xab, 0xc2,
-	0xfd, 0xd3, 0x84, 0x9a, 0x3f, 0xec, 0xaa, 0x9c, 0x6d, 0x28, 0xd2, 0x24, 0x48, 0x81, 0x34, 0x09,
-	0xd0, 0x43, 0x68, 0xc4, 0x09, 0xa1, 0x52, 0x2d, 0x21, 0x83, 0xc2, 0x5b, 0x2b, 0x9b, 0x17, 0xa2,
-	0x26, 0x54, 0x19, 0xa1, 0x82, 0xa3, 0xce, 0x2b, 0x9d, 0xa2, 0xbb, 0x50, 0x63, 0x1c, 0x07, 0x57,
-	0x02, 0x58, 0xd2, 0x4b, 0x62, 0xee, 0x85, 0x9b, 0xea, 0x96, 0xdf, 0x53, 0x77, 0x43, 0xb1, 0xca,
-	0xfb, 0x8a, 0x3d, 0x5b, 0x2b, 0x56, 0x95, 0x8a, 0xad, 0xae, 0x8a, 0x34, 0x9f, 0x0f, 0xf4, 0xbe,
-	0x27, 0x50, 0x61, 0x1c, 0xf3, 0x05, 0x6b, 0xd6, 0xe4, 0x31, 0xfd, 0xbf, 0xa3, 0xef, 0xb2, 0x41,
-	0x9a, 0x95, 0x4f, 0x58, 0xe2, 0x6b, 0xa7, 0x5b, 0xa9, 0xbb, 0x84, 0x2d, 0xc9, 0xa4, 0x8b, 0x39,
-	0x99, 0xc4, 0xf4, 0xba, 0x4d, 0xd2, 0x1b, 0x67, 0x17, 0xb6, 0xba, 0x83, 0xe3, 0xe3, 0xd3, 0xbe,
-	0xd7, 0x7d, 0x31, 0xf2, 0x06, 0x7d, 0xbb, 0x80, 0x76, 0xc0, 0xea, 0xf5, 0xcf, 0x3c, 0x7f, 0xd0,
-	0x3f, 0xee, 0xf5, 0x47, 0xb6, 0x81, 0xb6, 0xa0, 0xde, 0xfb, 0xe9, 0xd4, 0x1b, 0xca, 0xa9, 0x89,
-	0x2c, 0xa8, 0x9e, 0xf4, 0xfc, 0x33, 0xaf, 0xdb, 0xb3, 0x8b, 0x68, 0x1b, 0x60, 0xe8, 0x0f, 0xba,
-	0xbd, 0x93, 0x13, 0xaf, 0xff, 0xda, 0x2e, 0xa1, 0x06, 0xd4, 0x4e, 0x7a, 0xdd, 0x53, 0xdf, 0x1b,
-	0xbd, 0xb5, 0xcb, 0xed, 0x23, 0xb0, 0x65, 0xdc, 0x93, 0xc5, 0xf9, 0x2a, 0xf4, 0xd3, 0xcc, 0x85,
-	0x3c, 0x94, 0x01, 0xab, 0x50, 0x1c, 0xfc, 0x28, 0x02, 0x89, 0x81, 0x0c, 0x21, 0x07, 0xa7, 0x76,
-	0x51, 0x0c, 0xfa, 0x7d, 0xcf, 0x2e, 0xb5, 0x2f, 0xa0, 0xbe, 0xbe, 0x2f, 0xdf, 0xa6, 0x5b, 0xd8,
-	0xd0, 0xe8, 0x0e, 0xfa, 0x3f, 0x78, 0xaf, 0xc7, 0xbd, 0x33, 0x41, 0xae, 0x20, 0xb8, 0xbe, 0x19,
-	0x7a, 0x7a, 0x6a, 0x08, 0x7a, 0xab, 0xa9, 0x6b, 0x9b, 0x02, 0xf0, 0xaa, 0x27, 0xa8, 0x6b, 0x8f,
-	0xa2, 0x00, 0xf8, 0xc3, 0xae, 0x9e, 0x96, 0xda, 0x7f, 0x9b, 0x60, 0xc9, 0x40, 0x47, 0x04, 0x87,
-	0x84, 0x8a, 0xc2, 0x5e, 0x55, 0x9d, 0x19, 0x85, 0xe8, 0x19, 0xd4, 0x02, 0x9d, 0x89, 0x94, 0x79,
-	0xdb, 0xbd, 0x97, 0xfe, 0xee, 0x9c, 0xc2, 0xba, 0x3b, 0xac, 0x9c, 0xd1, 0x0b, 0x68, 0xb0, 0xc5,
-	0xf9, 0x78, 0x05, 0x2e, 0x4a, 0xf0, 0xfd, 0x1c, 0x38, 0x23, 0x93, 0xc6, 0x5b, 0x6c, 0x6d, 0x42,
-	0x8f, 0x75, 0x53, 0x2a, 0x49, 0xe8, 0xa7, 0x39, 0xe8, 0x7b, 0x1d, 0xe9, 0x21, 0x34, 0xc4, 0x77,
-	0xbc, 0x24, 0x94, 0x89, 0x93, 0xab, 0x8e, 0xb6, 0x25, 0x6c, 0x67, 0xca, 0x84, 0x9e, 0x41, 0x9d,
-	0xe2, 0x88, 0x91, 0x70, 0xcc, 0x99, 0x3c, 0xd9, 0x96, 0xdb, 0x72, 0xd4, 0xf3, 0xcb, 0x49, 0x9f,
-	0x5f, 0xce, 0x28, 0x7d, 0x7e, 0xf9, 0x35, 0xe5, 0x3c, 0x62, 0xe8, 0xb9, 0xa8, 0x9a, 0x24, 0xa6,
-	0x5c, 0x41, 0xab, 0x1f, 0x85, 0x42, 0xea, 0x3e, 0x62, 0xed, 0x3f, 0x4c, 0x28, 0xab, 0x32, 0x7f,
-	0x0c, 0x95, 0x4b, 0xa9, 0xb2, 0xbe, 0x02, 0xef, 0xe4, 0x32, 0x52, 0x3f, 0xc0, 0xd7, 0x2e, 0xe8,
-	0x00, 0x1a, 0x81, 0x7c, 0x7a, 0xa9, 0x36, 0xa7, 0x5b, 0xfb, 0x9d, 0x1b, 0x9e, 0x65, 0x47, 0x05,
-	0xdf, 0x0a, 0x32, 0x0f, 0xb9, 0x0e, 0xd4, 0xaf, 0x92, 0x48, 0xc3, 0x8a, 0x12, 0x66, 0x6f, 0x36,
-	0xf4, 0xa3, 0x82, 0x5f, 0xbb, 0x4a, 0x6f, 0x37, 0x17, 0x60, 0x05, 0x70, 0xa5, 0xda, 0x96, 0xbb,
-	0xbb, 0x89, 0x70, 0x8f, 0x0a, 0x7e, 0xfd, 0x6a, 0x75, 0x61, 0x1c, 0x40, 0x23, 0xdb, 0x85, 0xa5,
-	0xdc, 0x19, 0x7a, 0x99, 0xe6, 0x29, 0xe8, 0x65, 0xfa, 0xb2, 0xa0, 0x47, 0x93, 0x40, 0xc3, 0x2a,
-	0x79, 0x7a, 0x69, 0x07, 0x11, 0xf4, 0x68, 0x12, 0xc8, 0xf1, 0xcb, 0x06, 0x80, 0xea, 0xf4, 0xe2,
-	0x5f, 0xbe, 0xec, 0xc1, 0x9d, 0x98, 0x4e, 0x9c, 0x38, 0x21, 0xf3, 0x20, 0xa6, 0xa1, 0x46, 0xfe,
-	0xec, 0x4c, 0x22, 0x7e, 0xb9, 0x38, 0x17, 0x2d, 0xa5, 0x93, 0xae, 0x75, 0xd4, 0xda, 0x13, 0xfd,
-	0x72, 0x5e, 0x3e, 0xed, 0x4c, 0x62, 0x6d, 0x3b, 0xaf, 0x48, 0xe3, 0x37, 0xff, 0x06, 0x00, 0x00,
-	0xff, 0xff, 0x7b, 0x2c, 0xa9, 0x18, 0xdb, 0x0b, 0x00, 0x00,
+	// 1282 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xb4, 0x56, 0xdb, 0x6e, 0xdb, 0x46,
+	0x13, 0x16, 0xa9, 0xf3, 0x50, 0xb6, 0xe9, 0xcd, 0xff, 0xb7, 0x8a, 0xd2, 0x26, 0x8e, 0x8a, 0x16,
+	0x46, 0x82, 0x50, 0x28, 0x5b, 0x20, 0x86, 0x83, 0x1e, 0x12, 0x85, 0x8d, 0x89, 0xd4, 0x94, 0x4a,
+	0xcb, 0x06, 0xd2, 0x1b, 0x61, 0x4d, 0xae, 0x65, 0xc2, 0x92, 0x48, 0x70, 0x57, 0x42, 0xfc, 0x00,
+	0xbd, 0xee, 0x83, 0xf4, 0x39, 0x7a, 0xd7, 0x37, 0x28, 0x8a, 0xbe, 0x44, 0x1f, 0xa0, 0xd8, 0x03,
+	0x25, 0x52, 0x71, 0x90, 0x0b, 0xa3, 0x57, 0xdc, 0x9d, 0x9d, 0x6f, 0xe7, 0x9b, 0x8f, 0x3b, 0xb3,
+	0x0b, 0x9d, 0x65, 0x3c, 0x65, 0x97, 0x78, 0x9c, 0xa4, 0x31, 0x8b, 0x69, 0x8f, 0x2c, 0xc9, 0x9c,
+	0x51, 0x4b, 0xcc, 0x50, 0x4d, 0xae, 0x75, 0xda, 0x45, 0x9f, 0x19, 0x61, 0x58, 0x7a, 0x74, 0x3e,
+	0x99, 0xc4, 0xf1, 0x64, 0x4a, 0x7a, 0x38, 0x89, 0x7a, 0x78, 0x3e, 0x8f, 0x19, 0x66, 0x51, 0x3c,
+	0x57, 0xf8, 0xce, 0x03, 0xb5, 0x2a, 0x66, 0xe7, 0x8b, 0x8b, 0x1e, 0x8b, 0x66, 0x84, 0x32, 0x3c,
+	0x4b, 0x94, 0xc3, 0x46, 0xf0, 0x20, 0x9e, 0xcd, 0xe2, 0xb9, 0x5c, 0xeb, 0x3e, 0x83, 0x9d, 0x7e,
+	0x3c, 0xbf, 0x88, 0x26, 0x0e, 0xa7, 0x34, 0xba, 0x4e, 0x48, 0x77, 0x1f, 0xaa, 0xfc, 0x4b, 0x51,
+	0x1d, 0xca, 0x38, 0x0c, 0xcd, 0x12, 0x02, 0xa8, 0xa5, 0x64, 0x16, 0x2f, 0x89, 0xa9, 0xf1, 0xf1,
+	0x22, 0x09, 0x31, 0x23, 0xa6, 0xde, 0xbd, 0x04, 0x23, 0x07, 0x46, 0x5f, 0x42, 0x85, 0x5d, 0x27,
+	0xa4, 0xad, 0xed, 0x69, 0xfb, 0xdb, 0xf6, 0xa7, 0x96, 0x0c, 0x6b, 0x6d, 0xec, 0x6f, 0x89, 0xcd,
+	0x7d, 0xe1, 0x8a, 0x10, 0x54, 0x2e, 0x31, 0xbd, 0x6c, 0xeb, 0x7b, 0xda, 0x7e, 0xd3, 0x17, 0x63,
+	0x6e, 0x0b, 0x31, 0xc3, 0xed, 0xb2, 0xb4, 0xf1, 0x71, 0xf7, 0x11, 0xb4, 0x5e, 0x27, 0xd1, 0x9a,
+	0x63, 0x27, 0xe3, 0xd8, 0x84, 0x2a, 0x9d, 0x46, 0x01, 0x31, 0x4b, 0xa8, 0x06, 0x3a, 0xa3, 0xa6,
+	0xd6, 0xfd, 0x4d, 0x87, 0xed, 0x63, 0xc2, 0xd2, 0x28, 0x38, 0x26, 0x0c, 0xbf, 0xc4, 0x0c, 0xa3,
+	0xff, 0x41, 0x95, 0x45, 0x6c, 0x2a, 0xa9, 0x35, 0x7d, 0x39, 0x41, 0xdb, 0x1c, 0x20, 0x42, 0x6b,
+	0xbe, 0xce, 0x28, 0x7a, 0x04, 0xbb, 0xd3, 0x78, 0x12, 0x05, 0x78, 0x3a, 0x0e, 0xc9, 0x32, 0x0a,
+	0xc8, 0x38, 0x0a, 0x15, 0x8b, 0x1d, 0xb5, 0xf0, 0x52, 0xd8, 0xdd, 0x10, 0xdd, 0x83, 0x26, 0x25,
+	0x69, 0x84, 0xa7, 0xe3, 0x79, 0xdc, 0xae, 0x08, 0x9f, 0x86, 0x34, 0x78, 0x31, 0x5f, 0x5c, 0x6f,
+	0x50, 0x95, 0x8b, 0x61, 0x86, 0xfc, 0x06, 0xea, 0x41, 0x3c, 0x67, 0xe4, 0x2d, 0x6b, 0xd7, 0xf6,
+	0xca, 0xfb, 0x86, 0xfd, 0x59, 0x26, 0x54, 0x91, 0x34, 0xd7, 0x8d, 0x7b, 0x39, 0x73, 0x96, 0x5e,
+	0xfb, 0x19, 0x86, 0xab, 0xb3, 0x58, 0x44, 0x61, 0xbb, 0x2e, 0xd5, 0xe1, 0xe3, 0xce, 0x21, 0xb4,
+	0xf2, 0xce, 0xc8, 0x84, 0xf2, 0x15, 0xb9, 0x56, 0xc9, 0xf2, 0x21, 0x17, 0x60, 0x89, 0xa7, 0x0b,
+	0xa2, 0x84, 0x96, 0x93, 0x43, 0xfd, 0x40, 0xeb, 0xfe, 0xaa, 0x81, 0x29, 0x03, 0x9f, 0x71, 0xdb,
+	0x10, 0x47, 0x29, 0x45, 0xdf, 0x41, 0x7d, 0x26, 0x6c, 0xb4, 0xad, 0x09, 0x8e, 0x9f, 0x17, 0x39,
+	0xae, 0x5d, 0x95, 0x81, 0x2a, 0x96, 0x0a, 0xc5, 0x19, 0xe5, 0x17, 0x3e, 0xc4, 0x48, 0xcf, 0x33,
+	0xfa, 0x5d, 0x83, 0x5d, 0x09, 0x76, 0xe7, 0x17, 0x71, 0x3a, 0x13, 0x87, 0x1d, 0xd9, 0xd0, 0xe0,
+	0x15, 0x21, 0x4e, 0x06, 0xdf, 0xc6, 0xb0, 0x3f, 0xba, 0x59, 0x37, 0x7f, 0xe5, 0x87, 0xbe, 0x5f,
+	0xa7, 0xa1, 0x8b, 0x34, 0xbe, 0x28, 0x42, 0x72, 0xfb, 0xff, 0x07, 0x79, 0xfc, 0xa5, 0x41, 0x23,
+	0x3b, 0xb4, 0xc8, 0x2a, 0xd4, 0x46, 0x27, 0xe3, 0x91, 0x3f, 0xd4, 0x85, 0xc2, 0x58, 0x9f, 0x4d,
+	0x5d, 0x9c, 0xcd, 0x43, 0x68, 0x24, 0x29, 0xb9, 0x88, 0xde, 0x12, 0xda, 0x2e, 0x8b, 0x5c, 0xee,
+	0x6f, 0xee, 0x61, 0x0d, 0x95, 0x83, 0xcc, 0x61, 0xe5, 0xdf, 0x39, 0x85, 0xad, 0xc2, 0xd2, 0x0d,
+	0x59, 0x58, 0xf9, 0x2c, 0x0c, 0xbb, 0xfd, 0xbe, 0xdf, 0x9d, 0xcf, 0xef, 0x17, 0x0d, 0x9a, 0x59,
+	0x6c, 0xfb, 0x16, 0x09, 0xca, 0xe2, 0x3b, 0x00, 0x10, 0x85, 0x3c, 0x56, 0xb5, 0xcf, 0x53, 0xbc,
+	0xfb, 0xde, 0xdf, 0xe5, 0x37, 0x85, 0x33, 0xff, 0xdf, 0xdd, 0x7f, 0x34, 0x30, 0x64, 0x5d, 0x4a,
+	0xa9, 0x1f, 0x80, 0x91, 0x12, 0x1a, 0x2f, 0x52, 0x59, 0x7f, 0x32, 0x4b, 0xc8, 0x4c, 0x6e, 0xc8,
+	0xeb, 0x5c, 0x95, 0xa7, 0xe8, 0xc3, 0xe3, 0x39, 0x9e, 0x65, 0x85, 0xb1, 0x13, 0xae, 0x37, 0xf2,
+	0xf0, 0x8c, 0xa0, 0x3d, 0x30, 0x42, 0x42, 0x83, 0x34, 0x4a, 0x78, 0x58, 0xd5, 0x0d, 0xf2, 0x26,
+	0x74, 0xb8, 0xae, 0xe7, 0x8a, 0x60, 0xbd, 0x97, 0xb1, 0xce, 0x91, 0xba, 0xb9, 0x98, 0x6f, 0x55,
+	0xb8, 0x7f, 0xea, 0xd0, 0xf0, 0x87, 0x7d, 0x99, 0xb3, 0x09, 0xe5, 0x34, 0x09, 0x32, 0x60, 0x9a,
+	0x04, 0xe8, 0x21, 0xb4, 0xe2, 0x84, 0xa4, 0x42, 0x2d, 0x2e, 0x83, 0xc4, 0x1b, 0x2b, 0x9b, 0x1b,
+	0xa2, 0x36, 0xd4, 0x29, 0x49, 0x39, 0x47, 0x95, 0x57, 0x36, 0x45, 0x77, 0xa1, 0x41, 0x19, 0x0e,
+	0xae, 0x38, 0xb0, 0xa2, 0x96, 0xf8, 0xdc, 0x0d, 0x37, 0xd5, 0xad, 0xbe, 0xa3, 0xee, 0x86, 0x62,
+	0xb5, 0x77, 0x15, 0x7b, 0xba, 0x56, 0xac, 0x2e, 0x14, 0x5b, 0x5d, 0x15, 0x59, 0x3e, 0xef, 0xe9,
+	0x7d, 0x4f, 0xa0, 0x46, 0x19, 0x66, 0x0b, 0xda, 0x6e, 0x88, 0x63, 0xfa, 0x7f, 0x4b, 0xdd, 0x65,
+	0x83, 0x2c, 0x2b, 0x9f, 0xd0, 0xc4, 0x57, 0x4e, 0xb7, 0x52, 0x77, 0x09, 0x5b, 0x82, 0x49, 0x1f,
+	0x33, 0x32, 0x89, 0xd3, 0xeb, 0x2e, 0xc9, 0x6e, 0x9c, 0x5d, 0xd8, 0xea, 0x0f, 0x8e, 0x8f, 0x4f,
+	0x3d, 0xb7, 0xff, 0x7c, 0xe4, 0x0e, 0x3c, 0xb3, 0x84, 0x76, 0xc0, 0x70, 0xbc, 0x33, 0xd7, 0x1f,
+	0x78, 0xc7, 0x8e, 0x37, 0x32, 0x35, 0xb4, 0x05, 0x4d, 0xe7, 0xa7, 0x53, 0x77, 0x28, 0xa6, 0x3a,
+	0x32, 0xa0, 0x7e, 0xe2, 0xf8, 0x67, 0x6e, 0xdf, 0x31, 0xcb, 0x68, 0x1b, 0x60, 0xe8, 0x0f, 0xfa,
+	0xce, 0xc9, 0x89, 0xeb, 0xbd, 0x32, 0x2b, 0xa8, 0x05, 0x8d, 0x13, 0xa7, 0x7f, 0xea, 0xbb, 0xa3,
+	0x37, 0x66, 0xb5, 0xeb, 0x83, 0x29, 0xe2, 0x9e, 0x2c, 0xce, 0x57, 0xa1, 0xbf, 0xcd, 0x5d, 0xc8,
+	0x43, 0x11, 0xb0, 0x0e, 0xe5, 0xc1, 0x8f, 0x3c, 0x10, 0x1f, 0x88, 0x10, 0x62, 0x70, 0x6a, 0x96,
+	0xf9, 0xc0, 0xf3, 0x5c, 0xb3, 0x82, 0x1a, 0x50, 0xf1, 0x06, 0x9e, 0x63, 0x56, 0xbb, 0x17, 0xd0,
+	0x5c, 0xdf, 0x9c, 0x6f, 0xb2, 0xcd, 0x4c, 0x68, 0xf5, 0x07, 0xde, 0x0f, 0xee, 0xab, 0xb1, 0x73,
+	0xc6, 0x69, 0x96, 0x38, 0xeb, 0xd7, 0x43, 0x57, 0x4d, 0x35, 0x4e, 0x74, 0x35, 0xb5, 0x4d, 0x9d,
+	0x03, 0x5e, 0x3a, 0x3c, 0x09, 0xe5, 0x51, 0xe6, 0x00, 0x7f, 0xd8, 0x57, 0xd3, 0x4a, 0xf7, 0x6f,
+	0x1d, 0x0c, 0x11, 0xe8, 0x88, 0xe0, 0x90, 0xa4, 0xbc, 0xc4, 0x57, 0xf5, 0xa7, 0x47, 0x21, 0x7a,
+	0x0a, 0x8d, 0x40, 0xe5, 0x24, 0x04, 0xdf, 0xb6, 0xef, 0x65, 0x3f, 0xbe, 0xa0, 0xb5, 0xea, 0x13,
+	0x2b, 0x67, 0xf4, 0x1c, 0x5a, 0x74, 0x71, 0x3e, 0x5e, 0x81, 0xcb, 0x02, 0x7c, 0xbf, 0x00, 0xce,
+	0x09, 0xa6, 0xf0, 0x06, 0x5d, 0x9b, 0xd0, 0x63, 0xd5, 0x9e, 0x2a, 0x02, 0xfa, 0x71, 0x01, 0xfa,
+	0x4e, 0x6f, 0x7a, 0x08, 0x2d, 0xfe, 0x1d, 0x2f, 0x49, 0x4a, 0xf9, 0x19, 0x96, 0x87, 0xdc, 0xe0,
+	0xb6, 0x33, 0x69, 0x42, 0x4f, 0xa1, 0x99, 0xe2, 0x88, 0x92, 0x70, 0xcc, 0xa8, 0x38, 0xe3, 0x86,
+	0xdd, 0xb1, 0xe4, 0x43, 0xcc, 0xca, 0x1e, 0x62, 0xd6, 0x28, 0x7b, 0x88, 0xf9, 0x0d, 0xe9, 0x3c,
+	0xa2, 0xe8, 0x19, 0xaf, 0x9f, 0x24, 0x4e, 0x99, 0x84, 0xd6, 0x3f, 0x08, 0x85, 0xcc, 0x7d, 0x44,
+	0xbb, 0x7f, 0xe8, 0x50, 0x95, 0x05, 0xff, 0x18, 0x6a, 0x97, 0x42, 0x65, 0x75, 0x19, 0xde, 0x29,
+	0x64, 0x24, 0x7f, 0x80, 0xaf, 0x5c, 0xd0, 0x01, 0xb4, 0x02, 0xf1, 0x08, 0x93, 0x0d, 0x4f, 0x35,
+	0xf9, 0x3b, 0x37, 0x3c, 0xd0, 0x8e, 0x4a, 0xbe, 0x11, 0xe4, 0x9e, 0x74, 0x3d, 0x68, 0x5e, 0x25,
+	0x91, 0x82, 0x95, 0x05, 0xcc, 0xdc, 0x6c, 0xed, 0x47, 0x25, 0xbf, 0x71, 0x95, 0xdd, 0x73, 0x36,
+	0xc0, 0x0a, 0x60, 0x0b, 0xb5, 0x0d, 0x7b, 0x77, 0x13, 0x61, 0x1f, 0x95, 0xfc, 0xe6, 0xd5, 0xea,
+	0xea, 0x38, 0x80, 0x56, 0xbe, 0x1f, 0x0b, 0xb9, 0x73, 0xf4, 0x72, 0x6d, 0x94, 0xd3, 0xcb, 0x75,
+	0x68, 0x4e, 0x2f, 0x4d, 0x02, 0x05, 0xab, 0x15, 0xe9, 0x65, 0xbd, 0x84, 0xd3, 0x4b, 0x93, 0x40,
+	0x8c, 0x5f, 0xb4, 0x00, 0x64, 0xcf, 0xe7, 0xff, 0xf2, 0x85, 0x03, 0x77, 0xe2, 0x74, 0x62, 0xc5,
+	0x09, 0x99, 0x07, 0x71, 0x1a, 0x2a, 0xe4, 0xcf, 0xd6, 0x24, 0x62, 0x97, 0x8b, 0x73, 0xde, 0x5c,
+	0x7a, 0xd9, 0x5a, 0x4f, 0xae, 0x3d, 0x51, 0x6f, 0xe8, 0xe5, 0xd7, 0xbd, 0x49, 0xac, 0x6c, 0xe7,
+	0x35, 0x61, 0xfc, 0xea, 0xdf, 0x00, 0x00, 0x00, 0xff, 0xff, 0x4e, 0xd5, 0xe2, 0x3b, 0xe5, 0x0b,
+	0x00, 0x00,
 }
diff --git a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/voltha.pb.go b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/voltha.pb.go
index e34db79..2ec3452 100644
--- a/vendor/github.com/opencord/voltha-protos/v4/go/voltha/voltha.pb.go
+++ b/vendor/github.com/opencord/voltha-protos/v4/go/voltha/voltha.pb.go
@@ -124,7 +124,6 @@
 const OperationResp_OPERATION_SUCCESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_SUCCESS)
 const OperationResp_OPERATION_FAILURE = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_FAILURE)
 const OperationResp_OPERATION_UNSUPPORTED = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_UNSUPPORTED)
-const OperationResp_OPERATION_IN_PROGRESS = OperationResp_OperationReturnCode(common.OperationResp_OPERATION_IN_PROGRESS)
 
 // ValueType_Type from public import voltha_protos/common.proto
 type ValueType_Type = common.ValueType_Type
@@ -2198,173 +2197,171 @@
 func init() { proto.RegisterFile("voltha_protos/voltha.proto", fileDescriptor_e084f1a60ce7016c) }
 
 var fileDescriptor_e084f1a60ce7016c = []byte{
-	// 2650 bytes of a gzipped FileDescriptorProto
-	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x5a, 0x4b, 0x73, 0x1b, 0xc7,
-	0xf1, 0x27, 0xf8, 0x66, 0x03, 0x24, 0x81, 0x01, 0x1f, 0x10, 0x48, 0x4a, 0xe2, 0xf8, 0x45, 0xd3,
-	0x16, 0x60, 0x89, 0xb2, 0xcb, 0x7f, 0xfb, 0xef, 0x8a, 0xf9, 0x12, 0x8d, 0x48, 0x14, 0x90, 0x05,
-	0x29, 0x39, 0x89, 0x55, 0xa8, 0x05, 0x76, 0x00, 0x6e, 0x69, 0x81, 0x45, 0x76, 0x07, 0x94, 0x58,
-	0x2a, 0x55, 0xaa, 0x9c, 0x87, 0x73, 0xf7, 0x3d, 0xa7, 0xa4, 0x52, 0x95, 0xef, 0x91, 0xa3, 0x4f,
-	0x39, 0xe5, 0x9a, 0xca, 0x21, 0x9f, 0xc0, 0xe7, 0xd4, 0xf4, 0xcc, 0x02, 0xbb, 0xd8, 0x5d, 0x92,
-	0x70, 0x5c, 0x95, 0x13, 0xb9, 0xdd, 0x3d, 0xbf, 0xee, 0xe9, 0x9e, 0xe9, 0xe9, 0xe9, 0x01, 0xe4,
-	0xcf, 0x6d, 0x8b, 0x9f, 0xe9, 0xb5, 0xae, 0x63, 0x73, 0xdb, 0x2d, 0xca, 0xaf, 0x02, 0x7e, 0x91,
-	0x69, 0xf9, 0x95, 0x5f, 0x6f, 0xd9, 0x76, 0xcb, 0x62, 0x45, 0xbd, 0x6b, 0x16, 0xf5, 0x4e, 0xc7,
-	0xe6, 0x3a, 0x37, 0xed, 0x8e, 0x2b, 0xa5, 0xf2, 0x6b, 0x8a, 0x8b, 0x5f, 0xf5, 0x5e, 0xb3, 0xc8,
-	0xda, 0x5d, 0x7e, 0xa1, 0x98, 0xb9, 0x20, 0x7c, 0x9b, 0x71, 0x05, 0x9e, 0x1f, 0x52, 0xdc, 0xb0,
-	0xdb, 0x6d, 0xbb, 0x13, 0xcd, 0x3b, 0x63, 0xba, 0xc5, 0xcf, 0x14, 0x8f, 0x06, 0x79, 0x96, 0xdd,
-	0x32, 0x1b, 0xba, 0x55, 0x33, 0xd8, 0xb9, 0xd9, 0x60, 0xd1, 0xe3, 0x03, 0xbc, 0xb5, 0x20, 0x4f,
-	0x37, 0xf4, 0x2e, 0x67, 0x8e, 0x62, 0xde, 0x0a, 0x32, 0xed, 0x2e, 0xeb, 0x34, 0x2d, 0xfb, 0x45,
-	0xed, 0xee, 0x4e, 0x8c, 0x40, 0xbb, 0x61, 0xd6, 0xda, 0x66, 0xbd, 0x66, 0xd4, 0x95, 0xc0, 0x66,
-	0x84, 0x80, 0x6e, 0xe9, 0x4e, 0x7b, 0x20, 0x72, 0x33, 0x28, 0xc2, 0x5e, 0xf2, 0x5a, 0xc3, 0xee,
-	0x34, 0xcd, 0x96, 0xe4, 0xd3, 0x3f, 0x25, 0x20, 0x79, 0x80, 0x26, 0x1f, 0x39, 0x76, 0xaf, 0x4b,
-	0x96, 0x61, 0xdc, 0x34, 0x72, 0x89, 0xdb, 0x89, 0xad, 0xb9, 0xbd, 0xa9, 0x7f, 0x7f, 0xff, 0xdd,
-	0x46, 0x42, 0x1b, 0x37, 0x0d, 0x52, 0x82, 0xc5, 0xe0, 0xe4, 0xdd, 0xdc, 0xf8, 0xed, 0x89, 0xad,
-	0xe4, 0xbd, 0xe5, 0x82, 0x8a, 0xe2, 0x23, 0xc9, 0x96, 0x58, 0x7b, 0x73, 0xff, 0xfc, 0xfe, 0xbb,
-	0x8d, 0x49, 0x81, 0xa5, 0x2d, 0x58, 0x7e, 0x8e, 0x4b, 0x76, 0x60, 0xc6, 0x83, 0x98, 0x40, 0x88,
-	0x05, 0x0f, 0x22, 0x3c, 0xd6, 0x93, 0xa4, 0xff, 0x07, 0x29, 0x9f, 0x95, 0x2e, 0x79, 0x17, 0xa6,
-	0x4c, 0xce, 0xda, 0x6e, 0x2e, 0x81, 0x10, 0xd9, 0x20, 0x04, 0x0a, 0x69, 0x52, 0x82, 0xfe, 0x31,
-	0x01, 0xe4, 0xf0, 0x9c, 0x75, 0xf8, 0x03, 0xd3, 0xe2, 0xcc, 0xd1, 0x7a, 0x16, 0x7b, 0xc8, 0x2e,
-	0xe8, 0x37, 0x09, 0xc8, 0x0e, 0x91, 0x4f, 0x2e, 0xba, 0x8c, 0x2c, 0x00, 0x34, 0x91, 0x52, 0xd3,
-	0x2d, 0x2b, 0x3d, 0x46, 0x52, 0x30, 0xdb, 0xd0, 0x39, 0x6b, 0xd9, 0xce, 0x45, 0x3a, 0x41, 0xd2,
-	0x90, 0x72, 0x7b, 0xf5, 0x5a, 0x9f, 0x32, 0x4e, 0x08, 0x2c, 0x3c, 0xef, 0x9a, 0x35, 0x26, 0xa0,
-	0x6a, 0xfc, 0xa2, 0xcb, 0xd2, 0x13, 0x64, 0x19, 0x32, 0xd2, 0xc9, 0x7e, 0xf2, 0xa4, 0x20, 0xcb,
-	0xf9, 0xf8, 0xc9, 0x53, 0xd4, 0x84, 0xc5, 0x21, 0x43, 0xc8, 0xe7, 0x30, 0xf1, 0x9c, 0x5d, 0x60,
-	0x18, 0x16, 0xee, 0x15, 0xbc, 0xc9, 0x85, 0x67, 0x51, 0x88, 0x98, 0x81, 0x26, 0x86, 0x92, 0x25,
-	0x98, 0x3a, 0xd7, 0xad, 0x1e, 0xcb, 0x8d, 0x8b, 0x50, 0x6a, 0xf2, 0x83, 0xfe, 0x25, 0x01, 0x49,
-	0xdf, 0x90, 0xb8, 0x68, 0xaf, 0xc0, 0x34, 0xeb, 0xe8, 0x75, 0x4b, 0x8e, 0x9e, 0xd5, 0xd4, 0x17,
-	0x59, 0x83, 0x39, 0x35, 0x01, 0xd3, 0xc8, 0x4d, 0x20, 0xf0, 0xac, 0x24, 0x94, 0x0c, 0xb2, 0x01,
-	0x30, 0x98, 0x56, 0x6e, 0x12, 0xb9, 0x73, 0x48, 0x41, 0xbf, 0xde, 0x81, 0x29, 0xa7, 0x67, 0x31,
-	0x37, 0x37, 0x85, 0x11, 0x5b, 0x8d, 0x99, 0x94, 0x26, 0xa5, 0xe8, 0x67, 0x90, 0xf2, 0x71, 0x5c,
-	0x72, 0x07, 0x66, 0x64, 0x58, 0x42, 0x21, 0xf7, 0x03, 0x78, 0x32, 0xf4, 0x39, 0xa4, 0xf6, 0x6d,
-	0x87, 0x95, 0x3a, 0x2e, 0xd7, 0x3b, 0x0d, 0x46, 0xde, 0x86, 0xa4, 0xa9, 0xfe, 0xaf, 0x0d, 0xcf,
-	0x18, 0x3c, 0x4e, 0xc9, 0x20, 0x3b, 0x30, 0x2d, 0x13, 0x00, 0xce, 0x3c, 0x79, 0x6f, 0xc9, 0xd3,
-	0xf2, 0x05, 0x52, 0xab, 0x5c, 0xe7, 0x3d, 0x77, 0x6f, 0x4a, 0xac, 0xd0, 0x31, 0x4d, 0x89, 0xd2,
-	0x4f, 0x61, 0xde, 0xaf, 0xcc, 0x25, 0xdb, 0xc1, 0xd5, 0xd9, 0x07, 0xf1, 0x4b, 0x79, 0xcb, 0xf3,
-	0x43, 0x58, 0x2c, 0xb7, 0x1b, 0xe6, 0x09, 0x73, 0xb9, 0xc6, 0x7e, 0xd5, 0x63, 0x2e, 0x27, 0x0b,
-	0x83, 0xa8, 0x60, 0x38, 0x08, 0x4c, 0xf6, 0x7a, 0xa6, 0xa1, 0x42, 0x89, 0xff, 0xd3, 0x5f, 0x43,
-	0x4a, 0x0e, 0x71, 0xbb, 0x76, 0xc7, 0x65, 0xe4, 0x27, 0x30, 0xed, 0x30, 0xb7, 0x67, 0x71, 0xb5,
-	0x68, 0xde, 0xf1, 0x74, 0xfa, 0xa5, 0x02, 0x1f, 0x1a, 0x8a, 0x6b, 0x6a, 0x18, 0x2d, 0x00, 0x09,
-	0x73, 0x49, 0x12, 0x66, 0xaa, 0xa7, 0xfb, 0xfb, 0x87, 0xd5, 0x6a, 0x7a, 0x4c, 0x7c, 0x3c, 0xd8,
-	0x2d, 0x3d, 0x3a, 0xd5, 0x0e, 0xd3, 0x09, 0xfa, 0x0c, 0x66, 0x9f, 0x88, 0x35, 0x55, 0x65, 0x61,
-	0x83, 0x3f, 0x86, 0x94, 0x4c, 0x43, 0x72, 0x17, 0x28, 0x5f, 0x66, 0x0b, 0x2a, 0xf3, 0xec, 0x0a,
-	0xde, 0x3e, 0xfe, 0xff, 0xc5, 0x98, 0x96, 0xd4, 0x07, 0x9f, 0x7b, 0x33, 0x6a, 0xd9, 0xd2, 0x7f,
-	0x4c, 0xc2, 0xf4, 0x13, 0x9c, 0x01, 0xb9, 0x05, 0x33, 0xe7, 0xcc, 0x71, 0x4d, 0xbb, 0x13, 0x8c,
-	0x9b, 0x47, 0x25, 0x1f, 0xc1, 0xac, 0xca, 0xac, 0x5e, 0x56, 0x5a, 0xf4, 0x66, 0xbf, 0x2b, 0xe9,
-	0xfe, 0x9c, 0xd2, 0x97, 0x8d, 0x4a, 0x6a, 0x13, 0xff, 0x7d, 0x52, 0x9b, 0xbc, 0x6e, 0x52, 0x23,
-	0x9f, 0x43, 0x4a, 0x6d, 0x27, 0xb1, 0x65, 0xbc, 0x9d, 0x41, 0x82, 0x23, 0xc5, 0xe6, 0xf1, 0x8f,
-	0x4e, 0x1a, 0x7d, 0xb2, 0x4b, 0xf6, 0x61, 0x5e, 0x21, 0xb4, 0x30, 0x2f, 0xe6, 0xa6, 0x63, 0xd3,
-	0xa1, 0x1f, 0x43, 0xa9, 0x55, 0xb9, 0x74, 0x1f, 0xe6, 0xe5, 0xc6, 0xf5, 0x36, 0xd8, 0x4c, 0xec,
-	0x06, 0x0b, 0x80, 0x30, 0xff, 0xfe, 0xfc, 0x19, 0x64, 0x06, 0xe7, 0x93, 0xce, 0xf5, 0xba, 0xee,
-	0xb2, 0xdc, 0xba, 0x02, 0x12, 0x9c, 0xc2, 0xb1, 0x59, 0x97, 0xe6, 0x1c, 0xe8, 0x5c, 0xdf, 0x4b,
-	0x0b, 0xa0, 0xa4, 0x2f, 0x9f, 0x68, 0x8b, 0x42, 0x4a, 0x08, 0xa9, 0xd1, 0xe4, 0x29, 0x64, 0xfd,
-	0x27, 0x9a, 0x07, 0xba, 0xa1, 0x42, 0x84, 0xa0, 0xb8, 0x94, 0x2e, 0x85, 0x45, 0xb3, 0xa4, 0x98,
-	0x42, 0xa0, 0x7f, 0x4e, 0x40, 0xba, 0xca, 0xac, 0xe6, 0xf5, 0x36, 0xd0, 0xb0, 0xa4, 0x9f, 0xe0,
-	0xdf, 0x40, 0x15, 0x58, 0x08, 0x72, 0xe2, 0x37, 0x0f, 0xc9, 0xc0, 0xfc, 0xe3, 0xf2, 0x49, 0xad,
-	0x7a, 0x5a, 0xa9, 0x94, 0xb5, 0x93, 0xc3, 0x83, 0xf4, 0xb8, 0x20, 0x9d, 0x3e, 0x7e, 0xf8, 0xb8,
-	0xfc, 0xf4, 0x71, 0xed, 0x50, 0xd3, 0xca, 0x5a, 0x7a, 0x82, 0x96, 0x21, 0x53, 0x6e, 0xee, 0xb6,
-	0x58, 0x87, 0x57, 0x7b, 0x75, 0xb7, 0xe1, 0x98, 0x75, 0xe6, 0x88, 0x34, 0x6b, 0x37, 0x75, 0x41,
-	0xec, 0x27, 0x32, 0x6d, 0x4e, 0x51, 0x4a, 0x86, 0x48, 0xd1, 0xea, 0xc4, 0xef, 0x27, 0x8c, 0x59,
-	0x49, 0x28, 0x19, 0xf4, 0x53, 0x80, 0x63, 0xd6, 0xae, 0x33, 0xc7, 0x3d, 0x33, 0xbb, 0x02, 0x09,
-	0x57, 0x4d, 0xad, 0xa3, 0xb7, 0x99, 0x87, 0x84, 0x94, 0xc7, 0x7a, 0x9b, 0xa9, 0x4d, 0x3d, 0xee,
-	0x6d, 0x6a, 0x7a, 0x08, 0xa9, 0x07, 0x96, 0xfd, 0xe2, 0x98, 0x71, 0x5d, 0xc4, 0x82, 0x7c, 0x08,
-	0xd3, 0x6d, 0xe6, 0x4b, 0xc8, 0x1b, 0x05, 0x7f, 0x05, 0x63, 0x37, 0xbb, 0x35, 0x64, 0xab, 0x1c,
-	0xa0, 0x29, 0xe1, 0x7b, 0x7f, 0xbb, 0x0b, 0xf3, 0x72, 0x63, 0x57, 0x99, 0x23, 0x82, 0x44, 0x9e,
-	0xc2, 0xfc, 0x11, 0xe3, 0x3e, 0xc3, 0x56, 0x0a, 0xb2, 0xca, 0x2b, 0x78, 0x55, 0x5e, 0xe1, 0x50,
-	0x54, 0x79, 0xf9, 0xfe, 0xce, 0x18, 0xc8, 0xd2, 0xfc, 0xd7, 0x7f, 0xff, 0xd7, 0xb7, 0xe3, 0x4b,
-	0x84, 0x60, 0xc1, 0x78, 0x7e, 0xb7, 0xd8, 0x1e, 0xe0, 0x3c, 0x83, 0xf4, 0x69, 0xd7, 0xd0, 0x39,
-	0xf3, 0x61, 0x47, 0x60, 0xe4, 0x63, 0xf4, 0xd1, 0x0d, 0xc4, 0x5e, 0xa5, 0x11, 0xd8, 0x9f, 0x24,
-	0xb6, 0xc9, 0x01, 0xcc, 0x1d, 0x31, 0xae, 0x92, 0x54, 0x9c, 0xcd, 0xfd, 0x3c, 0x20, 0xe5, 0xe8,
-	0x22, 0x62, 0xce, 0x91, 0x19, 0x85, 0x49, 0x9e, 0x41, 0xe6, 0x91, 0xe9, 0xf2, 0xe0, 0x01, 0x12,
-	0x87, 0xb6, 0x1c, 0x75, 0x92, 0xb8, 0xf4, 0x06, 0x82, 0x66, 0x49, 0xc6, 0x33, 0xd4, 0xec, 0x23,
-	0x55, 0x61, 0xf1, 0x88, 0x05, 0xd0, 0x09, 0x14, 0x54, 0xfd, 0x5b, 0x3a, 0xc8, 0x47, 0x1e, 0x4d,
-	0xf4, 0x26, 0xe2, 0xe5, 0xc8, 0x4a, 0x08, 0xaf, 0xf8, 0xca, 0x34, 0x5e, 0x13, 0x0d, 0x52, 0xc2,
-	0xe6, 0x5d, 0x2f, 0x91, 0xc6, 0x99, 0x9b, 0x1e, 0x4a, 0xc3, 0x2e, 0xcd, 0x21, 0x32, 0x21, 0x69,
-	0x0f, 0xb9, 0x9f, 0x8c, 0x19, 0x10, 0x81, 0xf9, 0x28, 0x98, 0x57, 0xe3, 0x90, 0x57, 0x22, 0x33,
-	0xb4, 0x4b, 0x6f, 0x21, 0xfe, 0x0d, 0xb2, 0xea, 0xe1, 0x0f, 0x25, 0x78, 0xf2, 0x4b, 0x48, 0x1f,
-	0xb1, 0xa0, 0x96, 0x80, 0x43, 0xa2, 0x53, 0x3f, 0x7d, 0x13, 0x71, 0x6f, 0x92, 0xf5, 0x18, 0x5c,
-	0xe9, 0x97, 0x26, 0xac, 0x84, 0xe6, 0x50, 0xb1, 0x1d, 0xee, 0x46, 0xfb, 0x5c, 0xc9, 0xa1, 0x04,
-	0xdd, 0x46, 0x0d, 0x6f, 0x12, 0x7a, 0x99, 0x86, 0x62, 0x17, 0xd1, 0x5e, 0xc2, 0xd2, 0xf0, 0x24,
-	0x04, 0x08, 0x59, 0x8e, 0x40, 0x2e, 0x19, 0xf9, 0x6c, 0x04, 0x99, 0xde, 0x47, 0x7d, 0x05, 0xf2,
-	0xfe, 0xd5, 0xfa, 0x8a, 0xaf, 0xc4, 0x9f, 0x9a, 0x98, 0xe1, 0xef, 0x12, 0xb0, 0x7a, 0x88, 0xc5,
-	0xe0, 0xb5, 0xb5, 0xc7, 0xed, 0xae, 0x4f, 0xd1, 0x80, 0x0f, 0xe9, 0xce, 0x28, 0x06, 0x14, 0x55,
-	0x25, 0xfa, 0x4d, 0x02, 0x72, 0x07, 0xa6, 0xfb, 0xa3, 0x18, 0xf2, 0xff, 0x68, 0xc8, 0x47, 0xf4,
-	0xfe, 0x48, 0x86, 0x18, 0x52, 0x3b, 0x31, 0x22, 0x62, 0x2e, 0xf2, 0x64, 0x30, 0xe6, 0x24, 0x90,
-	0x1c, 0x91, 0x7f, 0xcd, 0x88, 0x37, 0x11, 0xeb, 0x37, 0x09, 0x58, 0x97, 0xb9, 0x2c, 0xa4, 0xe8,
-	0x04, 0xcd, 0x58, 0x0f, 0x29, 0x40, 0xba, 0x1c, 0x13, 0x3b, 0xf5, 0x3b, 0x68, 0xc2, 0x3b, 0xf4,
-	0x1a, 0x26, 0x88, 0x8c, 0xf7, 0xdb, 0x04, 0x6c, 0x44, 0x58, 0x71, 0x2c, 0x32, 0xbb, 0x34, 0x63,
-	0x2d, 0x60, 0x06, 0x32, 0x8e, 0x6d, 0xe3, 0x0a, 0x2b, 0x0a, 0x68, 0xc5, 0x16, 0x7d, 0xe3, 0x52,
-	0x2b, 0xe4, 0xf9, 0x21, 0xcc, 0x68, 0xc1, 0x6a, 0xc8, 0xe5, 0xa8, 0x2a, 0xe8, 0xf3, 0x6c, 0xd8,
-	0x16, 0x97, 0xbe, 0x87, 0xba, 0xde, 0x22, 0xd7, 0xd1, 0x45, 0x38, 0xac, 0x45, 0xc6, 0x56, 0x15,
-	0x4e, 0x7e, 0x65, 0xab, 0x21, 0xff, 0x4b, 0x21, 0xfa, 0x01, 0x2a, 0xdc, 0x26, 0x5b, 0x57, 0xba,
-	0x58, 0xd5, 0x70, 0xe4, 0xdb, 0x04, 0x6c, 0xc6, 0xc4, 0x1a, 0x31, 0xa5, 0xa7, 0x37, 0xa3, 0x15,
-	0x5e, 0x27, 0xea, 0x3b, 0x68, 0xd2, 0x1d, 0x7a, 0x6d, 0x93, 0x84, 0xd3, 0xcb, 0x90, 0x14, 0xbe,
-	0xb8, 0x2a, 0x31, 0x2f, 0x06, 0x4b, 0x4f, 0x97, 0xae, 0xa2, 0xb2, 0x0c, 0x59, 0xf4, 0x94, 0x79,
-	0x99, 0xb8, 0x0c, 0xf3, 0x03, 0xc0, 0x92, 0x11, 0x0f, 0x99, 0x1c, 0xb8, 0x39, 0xe2, 0xa8, 0x93,
-	0x70, 0xa6, 0xe1, 0x92, 0x53, 0x48, 0x6b, 0xac, 0x61, 0x77, 0x1a, 0xa6, 0xc5, 0x3c, 0x33, 0xfd,
-	0x63, 0x63, 0xfd, 0xb1, 0x8e, 0x98, 0x2b, 0x34, 0x8c, 0x29, 0x26, 0xee, 0xe0, 0x89, 0x21, 0x01,
-	0xa5, 0x63, 0x5d, 0x92, 0x0f, 0xce, 0x52, 0x92, 0x65, 0x29, 0x3c, 0x38, 0x41, 0x02, 0x43, 0xc2,
-	0x0b, 0x4f, 0x2a, 0xe9, 0x49, 0xb6, 0x74, 0xf9, 0x2b, 0x59, 0x81, 0xbf, 0x26, 0x87, 0x58, 0x5a,
-	0x44, 0x1c, 0x4f, 0x43, 0xd7, 0x0a, 0xcf, 0x74, 0xb2, 0x34, 0xe4, 0x5d, 0x79, 0x1e, 0xfd, 0x14,
-	0x52, 0xfb, 0x0e, 0xd3, 0xb9, 0x72, 0x07, 0x19, 0x1a, 0x1d, 0x42, 0x53, 0xc5, 0x14, 0x1d, 0x8e,
-	0x95, 0x70, 0xc3, 0x53, 0x48, 0xc9, 0xc4, 0x1f, 0x61, 0x55, 0x9c, 0x63, 0xdf, 0x40, 0xbc, 0x0d,
-	0xba, 0x16, 0x65, 0x9d, 0x97, 0xca, 0x7f, 0x0e, 0xf3, 0x2a, 0x93, 0x8f, 0x80, 0xac, 0xce, 0x63,
-	0xba, 0x1e, 0x89, 0xec, 0xe5, 0xe6, 0xa7, 0x90, 0xd2, 0x58, 0xdd, 0xb6, 0xf9, 0x8f, 0x66, 0xb3,
-	0x83, 0x70, 0x02, 0xf8, 0x80, 0x59, 0x8c, 0xff, 0x00, 0x67, 0x6c, 0x47, 0x03, 0x1b, 0x08, 0x47,
-	0xea, 0x90, 0x79, 0x60, 0x3b, 0x0d, 0x36, 0x32, 0xfa, 0xbb, 0x88, 0xfe, 0xc6, 0xf6, 0x66, 0x24,
-	0x7a, 0x53, 0x60, 0xd6, 0x94, 0x8e, 0x1e, 0xcc, 0x1f, 0xd8, 0x2f, 0x3a, 0x96, 0xad, 0x1b, 0xa5,
-	0xb6, 0xde, 0x62, 0x83, 0xf3, 0x12, 0x3f, 0x3d, 0x5e, 0x7e, 0xd9, 0x53, 0x5b, 0xee, 0x32, 0x07,
-	0xbb, 0xb0, 0xe2, 0x0a, 0x44, 0x3f, 0x42, 0x4d, 0x1f, 0xd0, 0xf7, 0x22, 0x35, 0x99, 0x02, 0xa2,
-	0x66, 0x28, 0x0c, 0xb7, 0xf8, 0x4a, 0x5c, 0x2e, 0x5e, 0x8b, 0x05, 0xf4, 0x75, 0x02, 0x56, 0x8e,
-	0x18, 0x0f, 0xe8, 0x90, 0xfd, 0x94, 0x78, 0x03, 0xa2, 0xc8, 0xf4, 0x13, 0x34, 0xe0, 0x3e, 0xb9,
-	0x37, 0x82, 0x01, 0x45, 0x57, 0x6a, 0xea, 0xe1, 0x66, 0x0e, 0xe0, 0x8d, 0xa8, 0x5d, 0x25, 0x4f,
-	0x32, 0xca, 0xf4, 0x49, 0x53, 0x16, 0xb7, 0x01, 0x24, 0x77, 0x28, 0xae, 0x51, 0xda, 0x5c, 0xfa,
-	0x3e, 0xaa, 0x7b, 0x9b, 0xbc, 0x79, 0x1d, 0x75, 0xe4, 0x25, 0x64, 0xf7, 0x45, 0x9d, 0x6e, 0x5d,
-	0x73, 0x86, 0x91, 0x01, 0x56, 0x33, 0xdc, 0x1e, 0x69, 0x86, 0x7f, 0x48, 0x40, 0x76, 0xb7, 0xc1,
-	0xcd, 0x73, 0x9d, 0x33, 0xd4, 0x22, 0xf3, 0xde, 0x88, 0xaa, 0xf7, 0x51, 0xf5, 0x67, 0xf4, 0xe3,
-	0x51, 0x42, 0x2b, 0xc9, 0x32, 0x91, 0x8a, 0x85, 0xf6, 0xfb, 0x04, 0x64, 0x34, 0x76, 0xce, 0x1c,
-	0xfe, 0x3f, 0x31, 0xc4, 0x41, 0xd5, 0xc2, 0x90, 0x0a, 0x2c, 0x0e, 0x4e, 0xb8, 0xf0, 0x3d, 0x60,
-	0xde, 0xb3, 0x48, 0x5e, 0x00, 0x28, 0xaa, 0x5c, 0x27, 0xf9, 0x48, 0x95, 0xb2, 0xf0, 0x7f, 0x06,
-	0x59, 0x1f, 0xa2, 0x6a, 0x9a, 0x05, 0x51, 0x33, 0x7d, 0x54, 0x8f, 0x4d, 0xdf, 0x41, 0xe4, 0x4d,
-	0x72, 0x2b, 0x1a, 0xd9, 0x6b, 0xd3, 0xb9, 0xa4, 0x03, 0xcb, 0xd2, 0x5b, 0xc3, 0x0a, 0xc2, 0xa0,
-	0xb1, 0x89, 0x48, 0x55, 0xb5, 0xf4, 0x2a, 0x65, 0xc2, 0x41, 0xa7, 0x7e, 0x07, 0x5d, 0xaf, 0x68,
-	0xbe, 0xdc, 0x4b, 0xb2, 0x58, 0x66, 0xb0, 0x14, 0x84, 0x1d, 0xa5, 0x5e, 0xdb, 0x42, 0x05, 0x94,
-	0xdc, 0x8e, 0x55, 0xe0, 0xd5, 0x69, 0x5f, 0xf9, 0xad, 0x97, 0xfd, 0xb8, 0xb8, 0x12, 0x26, 0x1b,
-	0xee, 0xe9, 0xb9, 0x71, 0x67, 0xb7, 0x6c, 0x06, 0x12, 0x0d, 0xbb, 0x22, 0x03, 0xf9, 0x21, 0xcf,
-	0x84, 0xf0, 0xe8, 0x26, 0xc2, 0xad, 0x91, 0x1b, 0x51, 0x70, 0xb2, 0x1e, 0xa8, 0x41, 0x7a, 0x60,
-	0xb1, 0x72, 0x4a, 0x9c, 0xc9, 0x4b, 0x11, 0x3d, 0x44, 0xd7, 0x6b, 0x89, 0x90, 0xe5, 0x21, 0x25,
-	0xca, 0x25, 0x0f, 0x20, 0x5d, 0xe5, 0x0e, 0xd3, 0xdb, 0x15, 0xbd, 0xf1, 0x9c, 0x71, 0xb7, 0xdc,
-	0xe3, 0x64, 0x25, 0xe0, 0x69, 0xc9, 0x28, 0xf7, 0x78, 0xec, 0x02, 0x1a, 0xdb, 0x4a, 0x90, 0x43,
-	0x2c, 0xe5, 0x98, 0x79, 0xce, 0x14, 0x50, 0xa9, 0x73, 0x49, 0x4f, 0x24, 0x8c, 0x5f, 0xea, 0xd0,
-	0xb1, 0x0f, 0x12, 0xe4, 0x21, 0x64, 0x15, 0xcc, 0xfe, 0x99, 0xde, 0x69, 0x31, 0xec, 0x64, 0xc6,
-	0x4f, 0x39, 0x17, 0x40, 0xf2, 0x0d, 0x41, 0xb0, 0x53, 0x58, 0xe8, 0x07, 0x44, 0xbe, 0x95, 0x05,
-	0x2f, 0x1b, 0x61, 0x77, 0xc5, 0x2d, 0x56, 0xe5, 0x2d, 0x2f, 0x26, 0x19, 0x59, 0xa3, 0xf9, 0xdf,
-	0x65, 0xa2, 0x7a, 0xaf, 0xf9, 0x28, 0x22, 0xbd, 0x8d, 0x2a, 0xf2, 0xb4, 0x1f, 0x90, 0x40, 0x2b,
-	0x57, 0x6c, 0xb2, 0x27, 0x68, 0xb7, 0x1f, 0x3d, 0xb2, 0x19, 0xe1, 0x7f, 0x6d, 0x09, 0x1b, 0x1e,
-	0x40, 0x95, 0x86, 0x1b, 0x90, 0x91, 0xc9, 0xe2, 0x87, 0x19, 0xfe, 0x16, 0xaa, 0xb8, 0x95, 0xbf,
-	0x44, 0x85, 0xb0, 0xde, 0x80, 0x8c, 0xac, 0x85, 0xae, 0xd4, 0x12, 0xb7, 0x9e, 0xd4, 0x5c, 0xb6,
-	0x2f, 0x9b, 0x8b, 0xda, 0x18, 0x81, 0x17, 0xa7, 0x2b, 0x37, 0x46, 0xc0, 0x63, 0xa1, 0x8d, 0x11,
-	0xd0, 0x42, 0x1e, 0x61, 0x41, 0x8f, 0x47, 0x8f, 0x1b, 0x5d, 0xd0, 0x4b, 0x9e, 0x57, 0x25, 0x92,
-	0xb5, 0xf8, 0x83, 0xc7, 0x25, 0x5f, 0xc2, 0xac, 0xd7, 0x6a, 0x0e, 0x80, 0xe5, 0xe2, 0x7a, 0xd6,
-	0xf4, 0x6d, 0x84, 0xbd, 0x4d, 0x6f, 0x46, 0xc2, 0xba, 0xcc, 0x6a, 0xd6, 0xb8, 0x40, 0x7b, 0x82,
-	0xf5, 0x51, 0xa0, 0x55, 0x3f, 0x7c, 0xa7, 0x0e, 0xf5, 0xf2, 0xc3, 0x99, 0x47, 0x6c, 0x23, 0x21,
-	0xa7, 0x2e, 0xd3, 0x66, 0x9d, 0x7c, 0x05, 0xe4, 0x88, 0xf1, 0xa1, 0x6e, 0xfd, 0x50, 0xe3, 0x2d,
-	0xaa, 0xa1, 0x1f, 0xf6, 0x47, 0x10, 0x1b, 0xdf, 0x06, 0x88, 0x0b, 0xf3, 0x55, 0xb3, 0xdd, 0xb3,
-	0x74, 0xce, 0x70, 0x3c, 0x59, 0xef, 0x3b, 0xc2, 0x4f, 0x56, 0xef, 0x6b, 0x71, 0x67, 0x7e, 0xa8,
-	0x19, 0x12, 0xf4, 0x91, 0x42, 0xaa, 0x09, 0x24, 0xb1, 0x32, 0xf7, 0x61, 0xae, 0xdf, 0x96, 0x27,
-	0x37, 0x3c, 0x85, 0xa1, 0x86, 0x7d, 0x3e, 0x9e, 0x45, 0xc7, 0xc8, 0x31, 0x80, 0xbc, 0x55, 0x61,
-	0xe3, 0x2a, 0xe5, 0xaf, 0x08, 0x62, 0x17, 0xb4, 0xba, 0x02, 0xd3, 0x05, 0x61, 0xe3, 0x60, 0xb4,
-	0xba, 0xa4, 0xab, 0xbb, 0xd4, 0x08, 0x78, 0x83, 0x5b, 0xdf, 0xf9, 0xdd, 0xa2, 0x6f, 0xb8, 0x00,
-	0xfc, 0x12, 0x92, 0x22, 0x79, 0xbc, 0xe4, 0xf8, 0xd6, 0x47, 0x56, 0x3c, 0xcf, 0xc9, 0xa7, 0xbf,
-	0x2e, 0x6b, 0x98, 0x4d, 0x93, 0x39, 0xf9, 0x25, 0x8f, 0xae, 0x31, 0xde, 0x73, 0x3a, 0xc8, 0x75,
-	0xe9, 0x1a, 0x02, 0x2f, 0x93, 0xac, 0xe7, 0x50, 0x3f, 0xd4, 0x09, 0x24, 0xab, 0xbe, 0xcf, 0x7e,
-	0xab, 0xd8, 0x7b, 0x54, 0x8c, 0x35, 0x37, 0x84, 0xea, 0x87, 0x39, 0x83, 0x6c, 0x95, 0xeb, 0x0e,
-	0xf7, 0x9e, 0x54, 0x45, 0x49, 0x6a, 0x77, 0x48, 0xff, 0xb5, 0x79, 0xe8, 0xa9, 0x75, 0xb0, 0x99,
-	0x03, 0xbb, 0x45, 0xa5, 0x0c, 0xda, 0xef, 0x22, 0xbb, 0x02, 0xb3, 0x86, 0xaf, 0x51, 0x62, 0x9b,
-	0x7c, 0x92, 0xd8, 0xde, 0xb3, 0x20, 0x6b, 0x3b, 0x2d, 0x3c, 0x31, 0x1a, 0xb6, 0x63, 0x28, 0x9c,
-	0xbd, 0x94, 0xec, 0xf3, 0x57, 0xf0, 0xe7, 0x16, 0xbf, 0x28, 0xb4, 0x4c, 0x7e, 0xd6, 0xab, 0x0b,
-	0xef, 0x14, 0x3d, 0x49, 0xf5, 0xb3, 0x97, 0x3b, 0xde, 0x8f, 0x60, 0xee, 0x17, 0x5b, 0xb6, 0xa2,
-	0xfd, 0x75, 0x7c, 0xa5, 0xec, 0xe1, 0x3d, 0xf1, 0x3f, 0x1b, 0x54, 0xc6, 0x2b, 0x13, 0x95, 0xc9,
-	0xca, 0x54, 0x65, 0xba, 0x32, 0x53, 0x99, 0xad, 0x4f, 0xe3, 0xd8, 0x9d, 0xff, 0x04, 0x00, 0x00,
-	0xff, 0xff, 0x16, 0x72, 0x40, 0x54, 0x50, 0x23, 0x00, 0x00,
+	// 2613 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x5a, 0x5b, 0x6f, 0x1b, 0xc7,
+	0xf5, 0x17, 0x75, 0xd7, 0x21, 0x25, 0x91, 0x43, 0x5d, 0x68, 0x4a, 0xb2, 0xad, 0xc9, 0x4d, 0x51,
+	0x62, 0xd2, 0xb1, 0x9c, 0x20, 0xff, 0xf8, 0x1f, 0x34, 0xba, 0x59, 0x61, 0x6d, 0x99, 0xec, 0x52,
+	0xb2, 0xd3, 0x36, 0x06, 0xb1, 0xe4, 0x0e, 0xa9, 0x85, 0x97, 0x5c, 0x76, 0x77, 0x28, 0x5b, 0x30,
+	0x82, 0x02, 0xe9, 0x25, 0x7d, 0xcf, 0x7b, 0x9f, 0x5a, 0x14, 0xe8, 0x77, 0xc9, 0x43, 0xd1, 0xa7,
+	0xbe, 0x16, 0x7d, 0xe8, 0x27, 0xc8, 0x73, 0x31, 0x67, 0x66, 0xc9, 0x5d, 0xee, 0xae, 0x24, 0xa6,
+	0x01, 0xfa, 0x24, 0xed, 0x39, 0x67, 0x7e, 0xe7, 0x36, 0x73, 0xe6, 0xec, 0x59, 0x42, 0xfe, 0xdc,
+	0xb6, 0xf8, 0x99, 0x5e, 0xeb, 0x3a, 0x36, 0xb7, 0xdd, 0xa2, 0x7c, 0x2a, 0xe0, 0x13, 0x99, 0x96,
+	0x4f, 0xf9, 0xf5, 0x96, 0x6d, 0xb7, 0x2c, 0x56, 0xd4, 0xbb, 0x66, 0x51, 0xef, 0x74, 0x6c, 0xae,
+	0x73, 0xd3, 0xee, 0xb8, 0x52, 0x2a, 0xbf, 0xa6, 0xb8, 0xf8, 0x54, 0xef, 0x35, 0x8b, 0xac, 0xdd,
+	0xe5, 0x17, 0x8a, 0x99, 0x0b, 0xc2, 0xb7, 0x19, 0x57, 0xe0, 0xf9, 0x21, 0xc5, 0x0d, 0xbb, 0xdd,
+	0xb6, 0x3b, 0xd1, 0xbc, 0x33, 0xa6, 0x5b, 0xfc, 0x4c, 0xf1, 0x68, 0x90, 0x67, 0xd9, 0x2d, 0xb3,
+	0xa1, 0x5b, 0x35, 0x83, 0x9d, 0x9b, 0x0d, 0x16, 0xbd, 0x3e, 0xc0, 0x5b, 0x0b, 0xf2, 0x74, 0x43,
+	0xef, 0x72, 0xe6, 0x28, 0xe6, 0xad, 0x20, 0xd3, 0xee, 0xb2, 0x4e, 0xd3, 0xb2, 0x5f, 0xd6, 0x3e,
+	0xd8, 0x89, 0x11, 0x68, 0x37, 0xcc, 0x5a, 0xdb, 0xac, 0xd7, 0x8c, 0xba, 0x12, 0xd8, 0x8c, 0x10,
+	0xd0, 0x2d, 0xdd, 0x69, 0x0f, 0x44, 0x6e, 0x06, 0x45, 0xd8, 0x2b, 0x5e, 0x6b, 0xd8, 0x9d, 0xa6,
+	0xd9, 0x92, 0x7c, 0xfa, 0xa7, 0x04, 0x24, 0x0f, 0xd0, 0xe4, 0x23, 0xc7, 0xee, 0x75, 0xc9, 0x32,
+	0x8c, 0x9b, 0x46, 0x2e, 0x71, 0x3b, 0xb1, 0x35, 0xb7, 0x37, 0xf5, 0xef, 0xef, 0xbf, 0xdb, 0x48,
+	0x68, 0xe3, 0xa6, 0x41, 0x4a, 0xb0, 0x18, 0x74, 0xde, 0xcd, 0x8d, 0xdf, 0x9e, 0xd8, 0x4a, 0xde,
+	0x5b, 0x2e, 0xa8, 0x2c, 0x3e, 0x96, 0x6c, 0x89, 0xb5, 0x37, 0xf7, 0xcf, 0xef, 0xbf, 0xdb, 0x98,
+	0x14, 0x58, 0xda, 0x82, 0xe5, 0xe7, 0xb8, 0x64, 0x07, 0x66, 0x3c, 0x88, 0x09, 0x84, 0x58, 0xf0,
+	0x20, 0xc2, 0x6b, 0x3d, 0x49, 0xfa, 0x7f, 0x90, 0xf2, 0x59, 0xe9, 0x92, 0x77, 0x61, 0xca, 0xe4,
+	0xac, 0xed, 0xe6, 0x12, 0x08, 0x91, 0x0d, 0x42, 0xa0, 0x90, 0x26, 0x25, 0xe8, 0x1f, 0x13, 0x40,
+	0x0e, 0xcf, 0x59, 0x87, 0x3f, 0x34, 0x2d, 0xce, 0x1c, 0xad, 0x67, 0xb1, 0x47, 0xec, 0x82, 0x7e,
+	0x93, 0x80, 0xec, 0x10, 0xf9, 0xe4, 0xa2, 0xcb, 0xc8, 0x02, 0x40, 0x13, 0x29, 0x35, 0xdd, 0xb2,
+	0xd2, 0x63, 0x24, 0x05, 0xb3, 0x0d, 0x9d, 0xb3, 0x96, 0xed, 0x5c, 0xa4, 0x13, 0x24, 0x0d, 0x29,
+	0xb7, 0x57, 0xaf, 0xf5, 0x29, 0xe3, 0x84, 0xc0, 0xc2, 0x8b, 0xae, 0x59, 0x63, 0x02, 0xaa, 0xc6,
+	0x2f, 0xba, 0x2c, 0x3d, 0x41, 0x96, 0x21, 0x23, 0x83, 0xec, 0x27, 0x4f, 0x0a, 0xb2, 0xf4, 0xc7,
+	0x4f, 0x9e, 0xa2, 0x26, 0x2c, 0x0e, 0x19, 0x42, 0x3e, 0x83, 0x89, 0x17, 0xec, 0x02, 0xd3, 0xb0,
+	0x70, 0xaf, 0xe0, 0x39, 0x17, 0xf6, 0xa2, 0x10, 0xe1, 0x81, 0x26, 0x96, 0x92, 0x25, 0x98, 0x3a,
+	0xd7, 0xad, 0x1e, 0xcb, 0x8d, 0x8b, 0x54, 0x6a, 0xf2, 0x81, 0xfe, 0x25, 0x01, 0x49, 0xdf, 0x92,
+	0xb8, 0x6c, 0xaf, 0xc0, 0x34, 0xeb, 0xe8, 0x75, 0x4b, 0xae, 0x9e, 0xd5, 0xd4, 0x13, 0x59, 0x83,
+	0x39, 0xe5, 0x80, 0x69, 0xe4, 0x26, 0x10, 0x78, 0x56, 0x12, 0x4a, 0x06, 0xd9, 0x00, 0x18, 0xb8,
+	0x95, 0x9b, 0x44, 0xee, 0x1c, 0x52, 0x30, 0xae, 0x77, 0x60, 0xca, 0xe9, 0x59, 0xcc, 0xcd, 0x4d,
+	0x61, 0xc6, 0x56, 0x63, 0x9c, 0xd2, 0xa4, 0x14, 0xfd, 0x14, 0x52, 0x3e, 0x8e, 0x4b, 0xee, 0xc0,
+	0x8c, 0x4c, 0x4b, 0x28, 0xe5, 0x7e, 0x00, 0x4f, 0x86, 0xbe, 0x80, 0xd4, 0xbe, 0xed, 0xb0, 0x52,
+	0xc7, 0xe5, 0x7a, 0xa7, 0xc1, 0xc8, 0xdb, 0x90, 0x34, 0xd5, 0xff, 0xb5, 0x61, 0x8f, 0xc1, 0xe3,
+	0x94, 0x0c, 0xb2, 0x03, 0xd3, 0xb2, 0x00, 0xa0, 0xe7, 0xc9, 0x7b, 0x4b, 0x9e, 0x96, 0xcf, 0x91,
+	0x5a, 0xe5, 0x3a, 0xef, 0xb9, 0x7b, 0x53, 0x62, 0x87, 0x8e, 0x69, 0x4a, 0x94, 0x3e, 0x80, 0x79,
+	0xbf, 0x32, 0x97, 0x6c, 0x07, 0x77, 0x67, 0x1f, 0xc4, 0x2f, 0xe5, 0x6d, 0xcf, 0x0f, 0x61, 0xb1,
+	0xdc, 0x6e, 0x98, 0x27, 0xcc, 0xe5, 0x1a, 0xfb, 0x55, 0x8f, 0xb9, 0x9c, 0x2c, 0x0c, 0xb2, 0x82,
+	0xe9, 0x20, 0x30, 0xd9, 0xeb, 0x99, 0x86, 0x4a, 0x25, 0xfe, 0x4f, 0x7f, 0x0d, 0x29, 0xb9, 0xc4,
+	0xed, 0xda, 0x1d, 0x97, 0x91, 0x9f, 0xc0, 0xb4, 0xc3, 0xdc, 0x9e, 0xc5, 0xd5, 0xa6, 0x79, 0xc7,
+	0xd3, 0xe9, 0x97, 0x0a, 0x3c, 0x68, 0x28, 0xae, 0xa9, 0x65, 0xb4, 0x00, 0x24, 0xcc, 0x25, 0x49,
+	0x98, 0xa9, 0x9e, 0xee, 0xef, 0x1f, 0x56, 0xab, 0xe9, 0x31, 0xf1, 0xf0, 0x70, 0xb7, 0xf4, 0xf8,
+	0x54, 0x3b, 0x4c, 0x27, 0xe8, 0x73, 0x98, 0x7d, 0x2a, 0xf6, 0x54, 0x95, 0x85, 0x0d, 0xfe, 0x18,
+	0x52, 0xb2, 0x0c, 0xc9, 0x53, 0xa0, 0x62, 0x99, 0x2d, 0xa8, 0xca, 0xb3, 0x2b, 0x78, 0xfb, 0xf8,
+	0xff, 0xe7, 0x63, 0x5a, 0x52, 0x1f, 0x3c, 0xee, 0xcd, 0xa8, 0x6d, 0x4b, 0xff, 0x31, 0x09, 0xd3,
+	0x4f, 0xd1, 0x03, 0x72, 0x0b, 0x66, 0xce, 0x99, 0xe3, 0x9a, 0x76, 0x27, 0x98, 0x37, 0x8f, 0x4a,
+	0x3e, 0x82, 0x59, 0x55, 0x59, 0xbd, 0xaa, 0xb4, 0xe8, 0x79, 0xbf, 0x2b, 0xe9, 0xfe, 0x9a, 0xd2,
+	0x97, 0x8d, 0x2a, 0x6a, 0x13, 0xff, 0x7d, 0x51, 0x9b, 0xbc, 0x6e, 0x51, 0x23, 0x9f, 0x41, 0x4a,
+	0x1d, 0x27, 0x71, 0x64, 0xbc, 0x93, 0x41, 0x82, 0x2b, 0xc5, 0xe1, 0xf1, 0xaf, 0x4e, 0x1a, 0x7d,
+	0xb2, 0x4b, 0xf6, 0x61, 0x5e, 0x21, 0xb4, 0xb0, 0x2e, 0xe6, 0xa6, 0x63, 0xcb, 0xa1, 0x1f, 0x43,
+	0xa9, 0x55, 0xb5, 0x74, 0x1f, 0xe6, 0xe5, 0xc1, 0xf5, 0x0e, 0xd8, 0x4c, 0xec, 0x01, 0x0b, 0x80,
+	0x30, 0xff, 0xf9, 0xfc, 0x19, 0x64, 0x06, 0xf7, 0x93, 0xce, 0xf5, 0xba, 0xee, 0xb2, 0xdc, 0xba,
+	0x02, 0x12, 0x9c, 0xc2, 0xb1, 0x59, 0x97, 0xe6, 0x1c, 0xe8, 0x5c, 0xdf, 0x4b, 0x0b, 0xa0, 0xa4,
+	0xaf, 0x9e, 0x68, 0x8b, 0x42, 0x4a, 0x08, 0xa9, 0xd5, 0xe4, 0x19, 0x64, 0xfd, 0x37, 0x9a, 0x07,
+	0xba, 0xa1, 0x52, 0x84, 0xa0, 0xb8, 0x95, 0x2e, 0x85, 0x45, 0xb3, 0xa4, 0x98, 0x42, 0xa0, 0x7f,
+	0x4e, 0x40, 0xba, 0xca, 0xac, 0xe6, 0xf5, 0x0e, 0xd0, 0xb0, 0xa4, 0x9f, 0xe0, 0x3f, 0x40, 0x15,
+	0x58, 0x08, 0x72, 0xe2, 0x0f, 0x0f, 0xc9, 0xc0, 0xfc, 0x93, 0xf2, 0x49, 0xad, 0x7a, 0x5a, 0xa9,
+	0x94, 0xb5, 0x93, 0xc3, 0x83, 0xf4, 0xb8, 0x20, 0x9d, 0x3e, 0x79, 0xf4, 0xa4, 0xfc, 0xec, 0x49,
+	0xed, 0x50, 0xd3, 0xca, 0x5a, 0x7a, 0x82, 0x96, 0x21, 0x53, 0x6e, 0xee, 0xb6, 0x58, 0x87, 0x57,
+	0x7b, 0x75, 0xb7, 0xe1, 0x98, 0x75, 0xe6, 0x88, 0x32, 0x6b, 0x37, 0x75, 0x41, 0xec, 0x17, 0x32,
+	0x6d, 0x4e, 0x51, 0x4a, 0x86, 0x28, 0xd1, 0xea, 0xc6, 0xef, 0x17, 0x8c, 0x59, 0x49, 0x28, 0x19,
+	0xf4, 0x01, 0xc0, 0x31, 0x6b, 0xd7, 0x99, 0xe3, 0x9e, 0x99, 0x5d, 0x81, 0x84, 0xbb, 0xa6, 0xd6,
+	0xd1, 0xdb, 0xcc, 0x43, 0x42, 0xca, 0x13, 0xbd, 0xcd, 0xd4, 0xa1, 0x1e, 0xf7, 0x0e, 0x35, 0x3d,
+	0x84, 0xd4, 0x43, 0xcb, 0x7e, 0x79, 0xcc, 0xb8, 0x2e, 0x72, 0x41, 0x3e, 0x84, 0xe9, 0x36, 0xf3,
+	0x15, 0xe4, 0x8d, 0x82, 0xbf, 0x83, 0xb1, 0x9b, 0xdd, 0x1a, 0xb2, 0x55, 0x0d, 0xd0, 0x94, 0xf0,
+	0xbd, 0xbf, 0xdd, 0x85, 0x79, 0x79, 0xb0, 0xab, 0xcc, 0x11, 0x49, 0x22, 0xcf, 0x60, 0xfe, 0x88,
+	0x71, 0x9f, 0x61, 0x2b, 0x05, 0xd9, 0xe5, 0x15, 0xbc, 0x2e, 0xaf, 0x70, 0x28, 0xba, 0xbc, 0x7c,
+	0xff, 0x64, 0x0c, 0x64, 0x69, 0xfe, 0xeb, 0xbf, 0xff, 0xeb, 0xdb, 0xf1, 0x25, 0x42, 0xb0, 0x61,
+	0x3c, 0xff, 0xa0, 0xd8, 0x1e, 0xe0, 0x3c, 0x87, 0xf4, 0x69, 0xd7, 0xd0, 0x39, 0xf3, 0x61, 0x47,
+	0x60, 0xe4, 0x63, 0xf4, 0xd1, 0x0d, 0xc4, 0x5e, 0xa5, 0x11, 0xd8, 0x9f, 0x24, 0xb6, 0xc9, 0x01,
+	0xcc, 0x1d, 0x31, 0xae, 0x8a, 0x54, 0x9c, 0xcd, 0xfd, 0x3a, 0x20, 0xe5, 0xe8, 0x22, 0x62, 0xce,
+	0x91, 0x19, 0x85, 0x49, 0x9e, 0x43, 0xe6, 0xb1, 0xe9, 0xf2, 0xe0, 0x05, 0x12, 0x87, 0xb6, 0x1c,
+	0x75, 0x93, 0xb8, 0xf4, 0x06, 0x82, 0x66, 0x49, 0xc6, 0x33, 0xd4, 0xec, 0x23, 0x55, 0x61, 0xf1,
+	0x88, 0x05, 0xd0, 0x09, 0x14, 0x54, 0xff, 0x5b, 0x3a, 0xc8, 0x47, 0x5e, 0x4d, 0xf4, 0x26, 0xe2,
+	0xe5, 0xc8, 0x4a, 0x08, 0xaf, 0xf8, 0xda, 0x34, 0xbe, 0x22, 0x1a, 0xa4, 0x84, 0xcd, 0xbb, 0x5e,
+	0x21, 0x8d, 0x33, 0x37, 0x3d, 0x54, 0x86, 0x5d, 0x9a, 0x43, 0x64, 0x42, 0xd2, 0x1e, 0x72, 0xbf,
+	0x18, 0x33, 0x20, 0x02, 0xf3, 0x71, 0xb0, 0xae, 0xc6, 0x21, 0xaf, 0x44, 0x56, 0x68, 0x97, 0xde,
+	0x42, 0xfc, 0x1b, 0x64, 0xd5, 0xc3, 0x1f, 0x2a, 0xf0, 0xe4, 0x97, 0x90, 0x3e, 0x62, 0x41, 0x2d,
+	0x81, 0x80, 0x44, 0x97, 0x7e, 0xfa, 0x26, 0xe2, 0xde, 0x24, 0xeb, 0x31, 0xb8, 0x32, 0x2e, 0x4d,
+	0x58, 0x09, 0xf9, 0x50, 0xb1, 0x1d, 0xee, 0x46, 0xc7, 0x5c, 0xc9, 0xa1, 0x04, 0xdd, 0x46, 0x0d,
+	0x6f, 0x12, 0x7a, 0x99, 0x86, 0x62, 0x17, 0xd1, 0x5e, 0xc1, 0xd2, 0xb0, 0x13, 0x02, 0x84, 0x2c,
+	0x47, 0x20, 0x97, 0x8c, 0x7c, 0x36, 0x82, 0x4c, 0xef, 0xa3, 0xbe, 0x02, 0x79, 0xff, 0x6a, 0x7d,
+	0xc5, 0xd7, 0xe2, 0x4f, 0x4d, 0x78, 0xf8, 0xbb, 0x04, 0xac, 0x1e, 0x62, 0x33, 0x78, 0x6d, 0xed,
+	0x71, 0xa7, 0xeb, 0x01, 0x1a, 0xf0, 0x21, 0xdd, 0x19, 0xc5, 0x80, 0xa2, 0xea, 0x44, 0xbf, 0x49,
+	0x40, 0xee, 0xc0, 0x74, 0x7f, 0x14, 0x43, 0xfe, 0x1f, 0x0d, 0xf9, 0x88, 0xde, 0x1f, 0xc9, 0x10,
+	0x43, 0x6a, 0x27, 0x46, 0x44, 0xce, 0x45, 0x9d, 0x0c, 0xe6, 0x9c, 0x04, 0x8a, 0x23, 0xf2, 0xaf,
+	0x99, 0xf1, 0x26, 0x62, 0xfd, 0x26, 0x01, 0xeb, 0xb2, 0x96, 0x85, 0x14, 0x9d, 0xa0, 0x19, 0xeb,
+	0x21, 0x05, 0x48, 0x97, 0x6b, 0x62, 0x5d, 0xbf, 0x83, 0x26, 0xbc, 0x43, 0xaf, 0x61, 0x82, 0xa8,
+	0x78, 0xbf, 0x4d, 0xc0, 0x46, 0x84, 0x15, 0xc7, 0xa2, 0xb2, 0x4b, 0x33, 0xd6, 0x02, 0x66, 0x20,
+	0xe3, 0xd8, 0x36, 0xae, 0xb0, 0xa2, 0x80, 0x56, 0x6c, 0xd1, 0x37, 0x2e, 0xb5, 0x42, 0xde, 0x1f,
+	0xc2, 0x8c, 0x16, 0xac, 0x86, 0x42, 0x8e, 0xaa, 0x82, 0x31, 0xcf, 0x86, 0x6d, 0x71, 0xe9, 0x7b,
+	0xa8, 0xeb, 0x2d, 0x72, 0x1d, 0x5d, 0x84, 0xc3, 0x5a, 0x64, 0x6e, 0x55, 0xe3, 0xe4, 0x57, 0xb6,
+	0x1a, 0x8a, 0xbf, 0x14, 0xa2, 0x77, 0x51, 0xe1, 0x36, 0xd9, 0xba, 0x32, 0xc4, 0xaa, 0x87, 0x23,
+	0xdf, 0x26, 0x60, 0x33, 0x26, 0xd7, 0x88, 0x29, 0x23, 0xbd, 0x19, 0xad, 0xf0, 0x3a, 0x59, 0xdf,
+	0x41, 0x93, 0xee, 0xd0, 0x6b, 0x9b, 0x24, 0x82, 0x5e, 0x86, 0xa4, 0x88, 0xc5, 0x55, 0x85, 0x79,
+	0x31, 0xd8, 0x7a, 0xba, 0x74, 0x15, 0x95, 0x65, 0xc8, 0xa2, 0xa7, 0xcc, 0xab, 0xc4, 0x65, 0x98,
+	0x1f, 0x00, 0x96, 0x8c, 0x78, 0xc8, 0xe4, 0x20, 0xcc, 0x11, 0x57, 0x9d, 0x84, 0x33, 0x0d, 0x97,
+	0x9c, 0x42, 0x5a, 0x63, 0x0d, 0xbb, 0xd3, 0x30, 0x2d, 0xe6, 0x99, 0xe9, 0x5f, 0x1b, 0x1b, 0x8f,
+	0x75, 0xc4, 0x5c, 0xa1, 0x61, 0x4c, 0xe1, 0xf8, 0x21, 0x5e, 0xf3, 0x11, 0x57, 0xc5, 0x50, 0x8b,
+	0xef, 0xc1, 0x90, 0xa5, 0x21, 0x4f, 0xe5, 0xdd, 0xf0, 0x53, 0x48, 0xed, 0x3b, 0x4c, 0xe7, 0xca,
+	0x34, 0x32, 0xb4, 0x3a, 0x84, 0xa6, 0x1a, 0x1b, 0x3a, 0x1c, 0x37, 0x61, 0xd2, 0x33, 0x48, 0xc9,
+	0x22, 0x1c, 0x61, 0x55, 0x9c, 0x93, 0x6f, 0x20, 0xde, 0x06, 0x5d, 0x8b, 0xb2, 0xce, 0x2b, 0xab,
+	0x3f, 0x87, 0x79, 0x55, 0x55, 0x47, 0x40, 0x56, 0x77, 0x23, 0x5d, 0x8f, 0x44, 0xf6, 0xea, 0xe4,
+	0x33, 0x48, 0x69, 0xac, 0x6e, 0xdb, 0xfc, 0x47, 0xb3, 0xd9, 0x41, 0x38, 0x01, 0x7c, 0xc0, 0x2c,
+	0xc6, 0x7f, 0x40, 0x30, 0xb6, 0xa3, 0x81, 0x0d, 0x84, 0x23, 0x75, 0xc8, 0x3c, 0xb4, 0x9d, 0x06,
+	0x1b, 0x19, 0xfd, 0x5d, 0x44, 0x7f, 0x63, 0x7b, 0x33, 0x12, 0xbd, 0x29, 0x30, 0x6b, 0x4a, 0x47,
+	0x0f, 0xe6, 0x0f, 0xec, 0x97, 0x1d, 0xcb, 0xd6, 0x8d, 0x52, 0x5b, 0x6f, 0xb1, 0xc1, 0xdd, 0x85,
+	0x8f, 0x1e, 0x2f, 0xbf, 0xec, 0xa9, 0x2d, 0x77, 0x99, 0x83, 0x13, 0x51, 0xf1, 0x3a, 0x42, 0x3f,
+	0x42, 0x4d, 0x77, 0xe9, 0x7b, 0x91, 0x9a, 0x4c, 0x01, 0x51, 0x33, 0x14, 0x86, 0x5b, 0x7c, 0x2d,
+	0x1a, 0xfd, 0xaf, 0xc4, 0x06, 0xfa, 0x3a, 0x01, 0x2b, 0x47, 0x8c, 0x07, 0x74, 0xc8, 0xd9, 0x46,
+	0xbc, 0x01, 0x51, 0x64, 0xfa, 0x09, 0x1a, 0x70, 0x9f, 0xdc, 0x1b, 0xc1, 0x80, 0xa2, 0x2b, 0x35,
+	0xf5, 0xb0, 0x15, 0x0b, 0xe0, 0x8d, 0xa8, 0x5d, 0x15, 0x32, 0x32, 0x8a, 0xfb, 0xa4, 0x29, 0x1b,
+	0xcd, 0x00, 0x92, 0x3b, 0x94, 0xd7, 0x28, 0x6d, 0x2e, 0x7d, 0x1f, 0xd5, 0xbd, 0x4d, 0xde, 0xbc,
+	0x8e, 0x3a, 0xf2, 0x0a, 0xb2, 0xfb, 0xa2, 0x67, 0xb6, 0xae, 0xe9, 0x61, 0x64, 0x82, 0x95, 0x87,
+	0xdb, 0x23, 0x79, 0xf8, 0x87, 0x04, 0x64, 0x77, 0x1b, 0xdc, 0x3c, 0xd7, 0x39, 0x43, 0x2d, 0xf2,
+	0x3e, 0x18, 0x51, 0xf5, 0x3e, 0xaa, 0xfe, 0x94, 0x7e, 0x3c, 0x4a, 0x6a, 0x25, 0xb9, 0x87, 0xfa,
+	0xc4, 0x46, 0xfb, 0x7d, 0x02, 0x32, 0x1a, 0x3b, 0x67, 0x0e, 0xff, 0x9f, 0x18, 0xe2, 0xa0, 0x6a,
+	0x61, 0x48, 0x05, 0x16, 0x07, 0xb7, 0x4d, 0xb8, 0x27, 0x9f, 0xf7, 0x2c, 0x92, 0xcd, 0x38, 0x45,
+	0x95, 0xeb, 0x24, 0x1f, 0xa9, 0x52, 0x36, 0xe1, 0xcf, 0x21, 0xeb, 0x43, 0x54, 0x03, 0xac, 0x20,
+	0x6a, 0xa6, 0x8f, 0xea, 0xb1, 0xe9, 0x3b, 0x88, 0xbc, 0x49, 0x6e, 0x45, 0x23, 0x7b, 0x23, 0x33,
+	0x97, 0x74, 0x60, 0x59, 0x46, 0x6b, 0x58, 0x41, 0x18, 0x34, 0xb6, 0x10, 0xa9, 0x0e, 0x93, 0x5e,
+	0xa5, 0x4c, 0x04, 0xe8, 0xd4, 0x1f, 0xa0, 0xeb, 0x35, 0xb0, 0x97, 0x47, 0x49, 0x36, 0xae, 0x0c,
+	0x96, 0x82, 0xb0, 0xa3, 0xf4, 0x4e, 0x5b, 0xa8, 0x80, 0x92, 0xdb, 0xb1, 0x0a, 0xbc, 0x9e, 0xe9,
+	0x4b, 0xbf, 0xf5, 0x72, 0x36, 0x16, 0xd7, 0x4e, 0x64, 0xc3, 0xf3, 0x35, 0x37, 0xee, 0xee, 0x96,
+	0x83, 0x39, 0xa2, 0xe1, 0x84, 0x62, 0x20, 0x3f, 0x14, 0x99, 0x10, 0x1e, 0xdd, 0x44, 0xb8, 0x35,
+	0x72, 0x23, 0x0a, 0x4e, 0xf6, 0x03, 0x35, 0x48, 0x0f, 0x2c, 0x56, 0x41, 0x89, 0x33, 0x79, 0x29,
+	0x62, 0x9e, 0xe7, 0x7a, 0xe3, 0x09, 0xb2, 0x3c, 0xa4, 0x44, 0x85, 0xe4, 0x21, 0xa4, 0xab, 0xdc,
+	0x61, 0x7a, 0xbb, 0xa2, 0x37, 0x5e, 0x30, 0xee, 0x96, 0x7b, 0x9c, 0xac, 0x04, 0x22, 0x2d, 0x19,
+	0xe5, 0x1e, 0x8f, 0xdd, 0x40, 0x63, 0x5b, 0x09, 0x72, 0x88, 0x6d, 0x15, 0x33, 0xcf, 0x99, 0x02,
+	0x2a, 0x75, 0x2e, 0x99, 0x4f, 0x84, 0xf1, 0x4b, 0x1d, 0x3a, 0x76, 0x37, 0x41, 0x1e, 0x41, 0x56,
+	0xc1, 0xec, 0x9f, 0xe9, 0x9d, 0x16, 0xc3, 0xa9, 0x62, 0xbc, 0xcb, 0xb9, 0x00, 0x92, 0x6f, 0x09,
+	0x82, 0x9d, 0xc2, 0x42, 0x3f, 0x21, 0xf2, 0xbb, 0x55, 0xb0, 0xf1, 0x0f, 0x87, 0x2b, 0x6e, 0xb3,
+	0xaa, 0x68, 0x79, 0x39, 0xc9, 0xc8, 0x1e, 0xcd, 0xff, 0x8d, 0x24, 0x6a, 0x0e, 0x9a, 0x8f, 0x22,
+	0xd2, 0xdb, 0xa8, 0x22, 0x4f, 0xfb, 0x09, 0x09, 0x8c, 0x55, 0xc5, 0x21, 0x7b, 0x8a, 0x76, 0xfb,
+	0xd1, 0x23, 0x07, 0x03, 0xfe, 0x2f, 0x1f, 0x61, 0xc3, 0x03, 0xa8, 0xd2, 0x70, 0x03, 0x32, 0xb2,
+	0x58, 0xfc, 0x30, 0xc3, 0xdf, 0x42, 0x15, 0xb7, 0xf2, 0x97, 0xa8, 0x10, 0xd6, 0x1b, 0x90, 0x91,
+	0xbd, 0xd0, 0x95, 0x5a, 0xe2, 0xf6, 0x93, 0xf2, 0x65, 0xfb, 0x32, 0x5f, 0xd4, 0xc1, 0x08, 0x7c,
+	0xfd, 0xb9, 0xf2, 0x60, 0x04, 0x22, 0x16, 0x3a, 0x18, 0x01, 0x2d, 0xe4, 0x31, 0x36, 0xf4, 0x78,
+	0xf5, 0xb8, 0xd1, 0x0d, 0xbd, 0xe4, 0x79, 0x5d, 0x22, 0x59, 0x8b, 0xbf, 0x78, 0x5c, 0xf2, 0x05,
+	0xcc, 0x7a, 0x63, 0xdf, 0x00, 0x58, 0x2e, 0x6e, 0x7e, 0x4c, 0xdf, 0x46, 0xd8, 0xdb, 0xf4, 0x66,
+	0x24, 0xac, 0xcb, 0xac, 0x66, 0x8d, 0x0b, 0xb4, 0xa7, 0xd8, 0x1f, 0x05, 0xc6, 0xe6, 0xc3, 0xef,
+	0xb7, 0xa1, 0xb9, 0x7a, 0xb8, 0xf2, 0x88, 0x63, 0x24, 0xe4, 0xd4, 0x8b, 0xad, 0x59, 0x27, 0x5f,
+	0x02, 0x39, 0x62, 0x7c, 0x68, 0x72, 0x3e, 0x34, 0x04, 0x8b, 0x1a, 0xae, 0x87, 0xe3, 0x11, 0xc4,
+	0xc6, 0x39, 0x3d, 0x71, 0x61, 0xbe, 0x6a, 0xb6, 0x7b, 0x96, 0xce, 0x19, 0xae, 0x27, 0xeb, 0xfd,
+	0x40, 0xf8, 0xc9, 0xea, 0x5b, 0x57, 0xdc, 0x9d, 0x1f, 0x1a, 0x4c, 0x04, 0x63, 0xa4, 0x90, 0x6a,
+	0x02, 0x49, 0xec, 0xcc, 0x7d, 0x98, 0xeb, 0x8f, 0xc8, 0xc9, 0x0d, 0x4f, 0x61, 0x68, 0x78, 0x9e,
+	0x8f, 0x67, 0xd1, 0x31, 0x72, 0x0c, 0x20, 0xdf, 0xaa, 0x70, 0x88, 0x94, 0xf2, 0x77, 0x04, 0xb1,
+	0x1b, 0x5a, 0xbd, 0x8e, 0xd2, 0x05, 0x61, 0xe3, 0x60, 0xb5, 0x7a, 0x61, 0x56, 0xef, 0x52, 0x23,
+	0xe0, 0x0d, 0xde, 0xfa, 0xce, 0x3f, 0x28, 0xfa, 0x96, 0x0b, 0xc0, 0x2f, 0x20, 0x29, 0x8a, 0xc7,
+	0x2b, 0x8e, 0xdf, 0xdd, 0xc8, 0x8a, 0x17, 0x39, 0xf9, 0x19, 0xae, 0xcb, 0x1a, 0x66, 0xd3, 0x64,
+	0x4e, 0x7e, 0xc9, 0xa3, 0x6b, 0x8c, 0xf7, 0x9c, 0x0e, 0x72, 0x5d, 0xba, 0x86, 0xc0, 0xcb, 0x24,
+	0xeb, 0x05, 0xd4, 0x0f, 0x75, 0x02, 0xc9, 0xaa, 0xef, 0xb1, 0x3f, 0xb6, 0xf5, 0x3e, 0xf0, 0xc5,
+	0x9a, 0x1b, 0x42, 0xf5, 0xc3, 0x9c, 0x41, 0xb6, 0xca, 0x75, 0x87, 0x7b, 0x9f, 0x37, 0x45, 0x4b,
+	0x6a, 0x77, 0x48, 0xff, 0xcb, 0xef, 0xd0, 0x67, 0xcf, 0xc1, 0x61, 0x0e, 0x9c, 0x16, 0x55, 0x32,
+	0x68, 0x7f, 0xa2, 0xeb, 0x0a, 0xcc, 0x1a, 0x7e, 0x19, 0x12, 0xc7, 0xe4, 0x93, 0xc4, 0xf6, 0x9e,
+	0x05, 0x59, 0xdb, 0x69, 0xe1, 0x8d, 0xd1, 0xb0, 0x1d, 0x43, 0xe1, 0xec, 0xa5, 0xe4, 0xcc, 0xbd,
+	0x82, 0x3f, 0x7d, 0xf8, 0x45, 0xa1, 0x65, 0xf2, 0xb3, 0x5e, 0x5d, 0x44, 0xa7, 0xe8, 0x49, 0xaa,
+	0x9f, 0xa0, 0xdc, 0xf1, 0x7e, 0x90, 0x72, 0xbf, 0xd8, 0xb2, 0x15, 0xed, 0xaf, 0xe3, 0x2b, 0x65,
+	0x0f, 0xef, 0xa9, 0x7f, 0x84, 0x5f, 0x19, 0xaf, 0x4c, 0x54, 0x26, 0x2b, 0x53, 0x95, 0xe9, 0xca,
+	0x4c, 0x65, 0xb6, 0x3e, 0x8d, 0x6b, 0x77, 0xfe, 0x13, 0x00, 0x00, 0xff, 0xff, 0xb4, 0x0e, 0xe5,
+	0xbc, 0xdc, 0x22, 0x00, 0x00,
 }
 
 // Reference imports to suppress errors if they are not otherwise used.
@@ -2421,8 +2418,6 @@
 	ListDeviceIds(ctx context.Context, in *empty.Empty, opts ...grpc.CallOption) (*common.IDs, error)
 	// Request to a voltha Core to reconcile a set of devices based on their IDs
 	ReconcileDevices(ctx context.Context, in *common.IDs, opts ...grpc.CallOption) (*empty.Empty, error)
-	// Get the device updates of a given device using a filter
-	GetDeviceUpdates(ctx context.Context, in *DeviceUpdateFilter, opts ...grpc.CallOption) (*DeviceUpdates, error)
 	// Get more information on a given physical device
 	GetDevice(ctx context.Context, in *common.ID, opts ...grpc.CallOption) (*Device, error)
 	// Pre-provision a new physical device
@@ -2712,15 +2707,6 @@
 	return out, nil
 }
 
-func (c *volthaServiceClient) GetDeviceUpdates(ctx context.Context, in *DeviceUpdateFilter, opts ...grpc.CallOption) (*DeviceUpdates, error) {
-	out := new(DeviceUpdates)
-	err := c.cc.Invoke(ctx, "/voltha.VolthaService/GetDeviceUpdates", in, out, opts...)
-	if err != nil {
-		return nil, err
-	}
-	return out, nil
-}
-
 func (c *volthaServiceClient) GetDevice(ctx context.Context, in *common.ID, opts ...grpc.CallOption) (*Device, error) {
 	out := new(Device)
 	err := c.cc.Invoke(ctx, "/voltha.VolthaService/GetDevice", in, out, opts...)
@@ -3214,8 +3200,6 @@
 	ListDeviceIds(context.Context, *empty.Empty) (*common.IDs, error)
 	// Request to a voltha Core to reconcile a set of devices based on their IDs
 	ReconcileDevices(context.Context, *common.IDs) (*empty.Empty, error)
-	// Get the device updates of a given device using a filter
-	GetDeviceUpdates(context.Context, *DeviceUpdateFilter) (*DeviceUpdates, error)
 	// Get more information on a given physical device
 	GetDevice(context.Context, *common.ID) (*Device, error)
 	// Pre-provision a new physical device
@@ -3690,24 +3674,6 @@
 	return interceptor(ctx, in, info, handler)
 }
 
-func _VolthaService_GetDeviceUpdates_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
-	in := new(DeviceUpdateFilter)
-	if err := dec(in); err != nil {
-		return nil, err
-	}
-	if interceptor == nil {
-		return srv.(VolthaServiceServer).GetDeviceUpdates(ctx, in)
-	}
-	info := &grpc.UnaryServerInfo{
-		Server:     srv,
-		FullMethod: "/voltha.VolthaService/GetDeviceUpdates",
-	}
-	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
-		return srv.(VolthaServiceServer).GetDeviceUpdates(ctx, req.(*DeviceUpdateFilter))
-	}
-	return interceptor(ctx, in, info, handler)
-}
-
 func _VolthaService_GetDevice_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
 	in := new(common.ID)
 	if err := dec(in); err != nil {
@@ -4567,10 +4533,6 @@
 			Handler:    _VolthaService_ReconcileDevices_Handler,
 		},
 		{
-			MethodName: "GetDeviceUpdates",
-			Handler:    _VolthaService_GetDeviceUpdates_Handler,
-		},
-		{
 			MethodName: "GetDevice",
 			Handler:    _VolthaService_GetDevice_Handler,
 		},